A B C D E F G H I J K L M N O P Q R S T U V W Z

A

abbreviate(String, int) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
convert "From src insert blah blah" to "From src insert ...
abortWriters(FileSystem, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
 
abs(int, Decimal128, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
abs(long) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
AbstractBucketJoinProc - Class in org.apache.hadoop.hive.ql.optimizer
this transformation does bucket map join optimization.
AbstractBucketJoinProc(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.AbstractBucketJoinProc
 
AbstractBucketJoinProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.AbstractBucketJoinProc
 
AbstractFilterStringColLikeStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
An abstract class for LIKE and REGEXP expressions.
AbstractFilterStringColLikeStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar
 
AbstractFilterStringColLikeStringScalar(int, String) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar
 
AbstractFilterStringColLikeStringScalar.Checker - Interface in org.apache.hadoop.hive.ql.exec.vector.expressions
A Checker contains a pattern and checks whether a given string matches or not.
AbstractGenericUDAFResolver - Class in org.apache.hadoop.hive.ql.udf.generic
An abstract class to help facilitate existing implementations of GenericUDAFResolver to migrate towards the newly introduced interface GenericUDAFResolver2.
AbstractGenericUDAFResolver() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.AbstractGenericUDAFResolver
 
AbstractGenericUDFEWAHBitmapBop - Class in org.apache.hadoop.hive.ql.udf.generic
An abstract class for a UDF that performs a binary operation between two EWAH-compressed bitmaps.
AbstractGenericUDFReflect - Class in org.apache.hadoop.hive.ql.udf.generic
common class for reflective UDFs
AbstractGenericUDFReflect() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.AbstractGenericUDFReflect
 
AbstractIndexHandler - Class in org.apache.hadoop.hive.ql.index
Abstract base class for index handlers.
AbstractIndexHandler() - Constructor for class org.apache.hadoop.hive.ql.index.AbstractIndexHandler
 
AbstractJoinTaskDispatcher - Class in org.apache.hadoop.hive.ql.optimizer.physical
Common iteration methods for converting joins and sort-merge joins.
AbstractJoinTaskDispatcher(PhysicalContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.AbstractJoinTaskDispatcher
 
AbstractMapJoinOperator<T extends MapJoinDesc> - Class in org.apache.hadoop.hive.ql.exec
 
AbstractMapJoinOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
AbstractMapJoinOperator(AbstractMapJoinOperator<? extends MapJoinDesc>) - Constructor for class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
AbstractMapJoinTableContainer - Class in org.apache.hadoop.hive.ql.exec.persistence
 
AbstractOperatorDesc - Class in org.apache.hadoop.hive.ql.plan
 
AbstractOperatorDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
AbstractParquetMapInspector - Class in org.apache.hadoop.hive.ql.io.parquet.serde
 
AbstractParquetMapInspector(ObjectInspector, ObjectInspector) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
AbstractRowContainer<ROW> - Interface in org.apache.hadoop.hive.ql.exec.persistence
 
AbstractRowContainer.RowIterator<ROW> - Interface in org.apache.hadoop.hive.ql.exec.persistence
 
AbstractSemanticAnalyzerHook - Class in org.apache.hadoop.hive.ql.parse
 
AbstractSemanticAnalyzerHook() - Constructor for class org.apache.hadoop.hive.ql.parse.AbstractSemanticAnalyzerHook
 
AbstractSMBJoinProc - Class in org.apache.hadoop.hive.ql.optimizer
 
AbstractSMBJoinProc(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.AbstractSMBJoinProc
 
AbstractSMBJoinProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.AbstractSMBJoinProc
 
acceptLimitPushdown() - Method in class org.apache.hadoop.hive.ql.exec.ExtractOperator
 
acceptLimitPushdown() - Method in class org.apache.hadoop.hive.ql.exec.ForwardOperator
 
acceptLimitPushdown() - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
we can push the limit above GBY (running in Reducer), since that will generate single row for each group.
acceptLimitPushdown() - Method in class org.apache.hadoop.hive.ql.exec.Operator
used for LimitPushdownOptimizer if all of the operators between limit and reduce-sink does not remove any input rows in the range of limit count, limit can be pushed down to reduce-sink operator.
acceptLimitPushdown() - Method in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
ACID_FORMAT - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater
 
ACID_KEY_INDEX_NAME - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater
 
ACID_STATS - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater
 
AcidInputFormat<V> - Interface in org.apache.hadoop.hive.ql.io
The interface required for input formats that what to support ACID transactions.
AcidInputFormat.Options - Class in org.apache.hadoop.hive.ql.io
Options for controlling the record readers.
AcidInputFormat.Options(Configuration) - Constructor for class org.apache.hadoop.hive.ql.io.AcidInputFormat.Options
Supply the configuration to use when reading.
AcidInputFormat.RawReader<V> - Interface in org.apache.hadoop.hive.ql.io
 
AcidInputFormat.RowReader<V> - Interface in org.apache.hadoop.hive.ql.io
 
AcidOutputFormat<V> - Interface in org.apache.hadoop.hive.ql.io
An extension for OutputFormats that want to implement ACID transactions.
AcidOutputFormat.Options - Class in org.apache.hadoop.hive.ql.io
Options to control how the files are written
AcidOutputFormat.Options(Configuration) - Constructor for class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
Create the options object.
AcidUtils - Class in org.apache.hadoop.hive.ql.io
Utilities that are shared by all of the ACID input and output formats.
AcidUtils.Directory - Interface in org.apache.hadoop.hive.ql.io
 
AcidUtils.ParsedDelta - Class in org.apache.hadoop.hive.ql.io
 
ACQUIRE_READ_WRITE_LOCKS - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
acquireLocks(QueryPlan, Context, String) - Method in class org.apache.hadoop.hive.ql.lockmgr.DbTxnManager
 
acquireLocks(QueryPlan, Context, String) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveTxnManager
Acquire all of the locks needed by a query.
adaptor - Static variable in class org.apache.hadoop.hive.ql.parse.ParseDriver
Tree adaptor for making antlr return ASTNodes instead of CommonTree nodes so that the graph walking algorithms and the rules framework defined in ql.lib can be used with the AST Nodes.
add(MapJoinObjectSerDeContext, BytesWritable, boolean) - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
Called when loading the hashtable.
add(int, Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
add(String, String) - Method in class org.apache.hadoop.hive.ql.parse.ColumnAccessInfo
 
add(TypeInfo) - Method in class org.apache.hadoop.hive.ql.parse.InputSignature
 
add(Operator<? extends OperatorDesc>, Map<String, List<String>>) - Method in class org.apache.hadoop.hive.ql.parse.TableAccessInfo
 
add(BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
add creates a new node in the graph without any connections
add(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Adds a new n-gram to the estimation.
add(double) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Adds a new data point to the histogram approximation.
add_builtin_resource(SessionState.ResourceType, String) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
add_resource(SessionState.ResourceType, String) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
add_resource(SessionState.ResourceType, String, boolean) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
addAdditionalSemanticInputs(HashSet<ReadEntity>) - Method in class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
addAggregationExprsForClause(String, LinkedHashMap<String, ASTNode>) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
addAlias(String, Integer) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.BucketCol
 
addAlias(String, Integer) - Method in interface org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.BucketSortCol
 
addAlias(String, Integer) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.SortCol
 
addAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
addAlias(ExprNodeDesc, String) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Adds the specified alias to the specified expr.
addAll(int, Collection<? extends Object>) - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
addAll(Collection<BaseWork>) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
add all nodes in the collection without any connections
addAll(BaseWork[]) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
add all nodes in the collection without any connections
addAll(SQLPrivTypeGrant[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.RequiredPrivileges
 
addAntlrPersistenceDelegates(XMLEncoder) - Static method in class org.apache.hadoop.hive.ql.exec.PTFUtils
 
addArg(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
addArg(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFunctionSpec
 
addArg(PTFExpressionDef) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
addArg(PTFExpressionDef) - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
addCandidateFilterOp(FilterOperator) - Method in class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
addChecked(int, Decimal128, Decimal128, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
addColumn(ExprNodeColumnDesc) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnListDesc
 
addComparisonOp(String) - Method in class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
Registers a comparison operator as one which can be satisfied by an index search.
addCompleteTask(TaskRunner) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
addConvertedNode(ExprNodeDesc, ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
adds a replacement node for this expression.
addCredentials(BaseWork, DAG) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
Set up credentials for the base work on secure clusters
addCS(String, ContentSummary) - Method in class org.apache.hadoop.hive.ql.Context
 
addDependentMoveTasks(Task<MoveWork>, HiveConf, Task<? extends Serializable>, DependencyCollectionTask) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Adds the dependencyTaskForMultiInsert in ctx as a dependent of parentTask.
addDependentTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
Add a dependent task on the current conditional task.
addDependentTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Task
Add a dependent task on the current task.
addDestToWindowingSpec(String, WindowingSpec) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
addDirectWorks(MapJoinOperator, List<Operator<? extends OperatorDesc>>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
addDummyOp(HashTableDummyOperator) - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
addDummyParentOp(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
addEnumDelegates(XMLEncoder) - Static method in class org.apache.hadoop.hive.ql.exec.PTFUtils
 
addEnv(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.exec.SecureCmdDoAs
 
addExpression(PTFInvocationSpec.OrderExpression) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderSpec
 
addExpression(PTFInvocationSpec.PartitionExpression) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionSpec
 
addExpression(OrderExpressionDef) - Method in class org.apache.hadoop.hive.ql.plan.ptf.OrderDef
 
addExpression(PTFExpressionDef) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionDef
 
addExprToStringBuffer(ExprNodeDesc, StringBuffer) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
addFilterMapping(int, int, int) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
addFinalCandidate(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Adds the specified expr as the top-most pushdown expr (ie all its children can be pushed).
addFunctionResources(List<ResourceUri>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionTask
 
addHivePersistenceDelegates(XMLEncoder) - Static method in class org.apache.hadoop.hive.ql.exec.PTFUtils
 
addIndexIntermediateFile(String) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
addInput(Set<ReadEntity>, ReadEntity) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
addInputsForView(ParseContext) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
addInsertIntoTable(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
addLateralViewForAlias(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
addListTopOperators(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
addLLFuncExprForTopExpr(ExprNodeDesc, ExprNodeGenericFuncDesc) - Method in class org.apache.hadoop.hive.ql.parse.LeadLagInfo
 
addLocalMapRedErrors(String, List<String>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
addMapWork(String, String, Operator<?>, PartitionDesc) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
addNonFinalCandidate(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Adds the specified expr as a non-final candidate
addOIPropertiestoSerDePropsMap(StructObjectInspector, Map<String, String>) - Static method in class org.apache.hadoop.hive.ql.plan.PTFDeserializer
 
addOperatorTableAccess(Operator<? extends OperatorDesc>, Map<String, List<String>>) - Method in class org.apache.hadoop.hive.ql.parse.TableAccessCtx
 
addPartition(Map<String, String>, String) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
addPartitionColsToBatch(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatchCtx
Add the partition values to the batch
AddPartitionDesc - Class in org.apache.hadoop.hive.ql.plan
Contains the information needed to add one or more partitions.
AddPartitionDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
For serialization only.
AddPartitionDesc(String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
AddPartitionDesc(String, String, Map<String, String>, String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
Deprecated. 
AddPartitionDesc.OnePartitionDesc - Class in org.apache.hadoop.hive.ql.plan
 
AddPartitionDesc.OnePartitionDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
addPath(FileSystem, String, long, int, Collection<Path>) - Static method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner
Try to recursively add files in sub-directories into retPathList until reaching the sizeLeft.
addPersistenceDelegates(XMLEncoder) - Static method in class org.apache.hadoop.hive.ql.exec.PTFUtils
 
addPostJoinFilter(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
addPrivilege(String, boolean) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.RequiredPrivileges
 
addPrivilege(SQLPrivTypeGrant) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.RequiredPrivileges
 
addPTFNodeToSpec(ASTNode, PTFInvocationSpec) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
addPushDowns(String, List<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Adds the passed list of pushDowns for the alias.
AddResourceProcessor - Class in org.apache.hadoop.hive.ql.processors
AddResourceProcessor.
AddResourceProcessor() - Constructor for class org.apache.hadoop.hive.ql.processors.AddResourceProcessor
 
addRHSSemijoin(String) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
Insert only a key to the semijoin table name to column names map.
addRHSSemijoinColumns(String, ArrayList<ASTNode>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
Remeber the mapping of table alias to set of columns.
addRHSSemijoinColumns(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
Remeber the mapping of table alias to set of columns.
addRootIfPossible(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
addRow(ROW) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer
add a row into the RowContainer
addRow(List<Object>) - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
addRow(Object[]) - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
addRow(List<Object>) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
addRow(Object[]) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
addRow(Object[]) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinRowContainer
 
addRow(Row) - Method in class org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer
 
addRow(ROW) - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
addRow(Object) - Method in interface org.apache.hadoop.hive.ql.io.orc.Writer
Add a row to the ORC file.
addRowToBatch(Object, StructObjectInspector, int, VectorizedRowBatch, DataOutputBuffer) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
Iterates thru all the columns in a given row and populates the batch
addRowToBatch(int, Writable, VectorizedRowBatch, DataOutputBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatchCtx
Adds the row to the batch after deserializing the row
addSampleFile(Path, JobConf) - Method in class org.apache.hadoop.hive.ql.exec.PartitionKeySampler
 
addSeenOp(Task, Operator) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
addSlash(String) - Static method in class org.apache.hadoop.hive.ql.exec.ArchiveUtils
 
addSlash(URI) - Static method in class org.apache.hadoop.hive.ql.exec.ArchiveUtils
Makes sure, that URI points to directory by adding slash to it.
addStatsTask(FileSinkOperator, MoveTask, Task<? extends Serializable>, HiveConf) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Add the StatsTask as a dependent task of the MoveTask because StatsTask will change the Table/Partition metadata.
addTable(String, String) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
addTableSpec(String, BaseSemanticAnalyzer.tableSpec) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
addTaskAttemptLogUrl(String) - Method in class org.apache.hadoop.hive.ql.exec.errors.TaskLogProcessor
Adds a task log URL for the heuristics to read through.
addTaskTmpDir(String) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
addToAllReduceSinkOperators(ReduceSinkOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.IntraQueryCorrelation
 
addToClassPath(ClassLoader, String[]) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Add new elements to the classpath.
addToClassPath(ClassLoader, String[], boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
addToColumnMap(String, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
addToColumnStats(List<ColStatistics>) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
addToDataSize(long) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
addToDispatchList(Node) - Method in class org.apache.hadoop.hive.ql.lib.TaskGraphWalker.TaskGraphWalkerContext
 
addToEstimator(HiveDecimal) - Method in class org.apache.hadoop.hive.ql.udf.generic.DecimalNumDistinctValueEstimator
 
addToEstimator(double) - Method in class org.apache.hadoop.hive.ql.udf.generic.DoubleNumDistinctValueEstimator
 
addToEstimator(long) - Method in class org.apache.hadoop.hive.ql.udf.generic.LongNumDistinctValueEstimator
 
addToEstimator(long) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
addToEstimator(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.StringNumDistinctValueEstimator
 
addToEstimatorPCSA(HiveDecimal) - Method in class org.apache.hadoop.hive.ql.udf.generic.DecimalNumDistinctValueEstimator
 
addToEstimatorPCSA(double) - Method in class org.apache.hadoop.hive.ql.udf.generic.DoubleNumDistinctValueEstimator
 
addToEstimatorPCSA(long) - Method in class org.apache.hadoop.hive.ql.udf.generic.LongNumDistinctValueEstimator
 
addToEstimatorPCSA(long) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
addToEstimatorPCSA(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.StringNumDistinctValueEstimator
 
addToNumRows(long) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
addToRootTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
addToRunnable(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.DriverContext
 
addToStat(String, long) - Method in class org.apache.hadoop.hive.ql.exec.Stat
 
addTTDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
addUnionOperators(Collection<UnionOperator>) - Method in class org.apache.hadoop.hive.ql.plan.UnionWork
 
addUserMetadata(String, ByteBuffer) - Method in interface org.apache.hadoop.hive.ql.io.orc.Writer
Add arbitrary meta-data to the ORC file.
addVirtualCols(List<VirtualColumn>) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
addWindowFunction(WindowingSpec.WindowFunctionSpec) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec
 
addWindowingExprToClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
addWindowSpec(String, WindowingSpec.WindowSpec) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec
 
adjustNumReducers(int) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.IntraQueryCorrelation
 
aggregate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
This function will be called by GroupByOperator when it sees a new input row.
AggregateIndexHandler - Class in org.apache.hadoop.hive.ql.index
Index handler for indexes that have aggregate functions on indexed columns.
AggregateIndexHandler() - Constructor for class org.apache.hadoop.hive.ql.index.AggregateIndexHandler
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorAggregateExpression
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFAvgDecimal
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCount
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCountStar
 
aggregateInput(VectorAggregateExpression.AggregationBuffer, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFSumDecimal
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorAggregateExpression
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFAvgDecimal
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCount
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCountStar
 
aggregateInputSelection(VectorAggregationBufferRow[], int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFSumDecimal
 
aggregateStats(String, String) - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsAggregator
 
aggregateStats(String, String) - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsAggregatorTez
 
aggregateStats(String, String) - Method in class org.apache.hadoop.hive.ql.stats.fs.FSStatsAggregator
 
aggregateStats(String, String) - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsAggregator
 
aggregateStats(String, String) - Method in interface org.apache.hadoop.hive.ql.stats.StatsAggregator
This method aggregates a given statistic from all tasks (partial stats).
AggregationDesc - Class in org.apache.hadoop.hive.ql.plan
AggregationDesc.
AggregationDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
AggregationDesc(String, GenericUDAFEvaluator, ArrayList<ExprNodeDesc>, boolean, GenericUDAFEvaluator.Mode) - Constructor for class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
alignUp(int, int) - Static method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
ALL - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
allFile - Variable in class org.apache.hadoop.hive.ql.optimizer.SamplePruner.AddPathReturnStatus
 
allMapOnlySubQ() - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
allMapOnlySubQSet() - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
alloc() - Method in interface org.apache.hadoop.hive.ql.exec.vector.VectorUtilBatchObjectPool.IAllocator
 
allocate(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Sets the number of histogram bins to use for approximating data.
allocateKeyWrapper() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapperBatch
 
allocatePartitionDescMap() - Method in class org.apache.hadoop.hive.ql.io.IOPrepareCache
 
allowColumnName(String) - Method in class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
Adds a column name to the set of column names allowed.
allRootTasks() - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
ALLSCOPE - Static variable in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeScope
 
ALLSCOPE_EXCEPT_COLUMN - Static variable in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeScope
 
ALTER_DATA - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
ALTER_METADATA - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
alterDatabase(String, Database) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
AlterDatabaseDesc - Class in org.apache.hadoop.hive.ql.plan
AlterDatabaseDesc.
AlterDatabaseDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
For serialization only.
AlterDatabaseDesc(String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
AlterDatabaseDesc(String, PrincipalDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
AlterDatabaseDesc.ALTER_DB_TYPES - Enum in org.apache.hadoop.hive.ql.plan
 
alterFunction(String, String, Function) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
alterIndex(String, String, String, Index) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Updates the existing index metadata with the new metadata.
AlterIndexDesc - Class in org.apache.hadoop.hive.ql.plan
AlterIndexDesc.
AlterIndexDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
AlterIndexDesc(AlterIndexDesc.AlterIndexTypes) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
AlterIndexDesc.AlterIndexTypes - Enum in org.apache.hadoop.hive.ql.plan
alterIndexTypes.
alterPartition(String, Partition) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Updates the existing partition metadata with the new metadata.
alterPartition(String, String, Partition) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Updates the existing partition metadata with the new metadata.
alterPartitions(String, List<Partition>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Updates the existing table metadata with the new metadata.
alterTable(String, Table) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Updates the existing table metadata with the new metadata.
AlterTableAlterPartDesc - Class in org.apache.hadoop.hive.ql.plan
 
AlterTableAlterPartDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableAlterPartDesc
 
AlterTableAlterPartDesc(String, String, FieldSchema) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableAlterPartDesc
 
AlterTableDesc - Class in org.apache.hadoop.hive.ql.plan
AlterTableDesc.
AlterTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, String, String, String, String, boolean, String) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, List<FieldSchema>, AlterTableDesc.AlterTableTypes) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(AlterTableDesc.AlterTableTypes) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(AlterTableDesc.AlterTableTypes, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, String, String, String, String, HashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, int, List<String>, List<Order>, HashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, boolean, HashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, String, HashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, Map<List<String>, String>, HashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, boolean, List<String>, List<List<String>>) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, HashMap<String, String>, int) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc.AlterTableTypes - Enum in org.apache.hadoop.hive.ql.plan
alterTableTypes.
AlterTableDesc.ProtectModeType - Enum in org.apache.hadoop.hive.ql.plan
 
AlterTableExchangePartition - Class in org.apache.hadoop.hive.ql.plan
 
AlterTableExchangePartition(Table, Table, Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableExchangePartition
 
AlterTablePartMergeFilesDesc - Class in org.apache.hadoop.hive.ql.parse
 
AlterTablePartMergeFilesDesc(String, HashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.parse.AlterTablePartMergeFilesDesc
 
AlterTableSimpleDesc - Class in org.apache.hadoop.hive.ql.plan
Contains information needed to modify a partition or a table
AlterTableSimpleDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
AlterTableSimpleDesc(String, String, Map<String, String>, AlterTableDesc.AlterTableTypes) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
AlterTableSimpleDesc(String, String, LinkedHashMap<String, String>, String) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
Constructor for ALTER TABLE ...
AmbiguousMethodException - Exception in org.apache.hadoop.hive.ql.exec
Exception thrown by the UDF and UDAF method resolvers in case a unique method is not found.
AmbiguousMethodException(Class<?>, List<TypeInfo>, List<Method>) - Constructor for exception org.apache.hadoop.hive.ql.exec.AmbiguousMethodException
Constructor.
ANALYZE - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
analyze(ASTNode, Context) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
analyze(ASTNode, Context) - Method in class org.apache.hadoop.hive.ql.parse.ColumnStatsSemanticAnalyzer
 
analyzeColumnAccess() - Method in class org.apache.hadoop.hive.ql.parse.ColumnAccessAnalyzer
 
analyzeIndexDefinition(Table, Index, Table) - Method in class org.apache.hadoop.hive.ql.index.AggregateIndexHandler
 
analyzeIndexDefinition(Table, Index, Table) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapIndexHandler
 
analyzeIndexDefinition(Table, Index, Table) - Method in class org.apache.hadoop.hive.ql.index.compact.CompactIndexHandler
 
analyzeIndexDefinition(Table, Index, Table) - Method in interface org.apache.hadoop.hive.ql.index.HiveIndexHandler
Requests that the handler validate an index definition and fill in additional information about its stored representation.
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.DDLSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.ExplainSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.ExportSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.FunctionSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.ImportSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.LoadSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.MacroSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
analyzePredicate(ExprNodeDesc, List<IndexSearchCondition>) - Method in class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
Analyzes a predicate.
analyzePrincipalListDef(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.authorization.AuthorizationParseUtils
 
analyzeTableAccess() - Method in class org.apache.hadoop.hive.ql.parse.TableAccessAnalyzer
 
and(SearchArgument.TruthValue) - Method in enum org.apache.hadoop.hive.ql.io.sarg.SearchArgument.TruthValue
Compute logical AND between the two values.
andBoolOperand(Boolean, Boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPrunerUtils
And 2 Boolean operands in the context of pruning match Operand one|Operand another | And result unknown | T | unknown unknown | F | F unknown | unknown | unknown T | T | T T | F | F T | unknown | unknown F | T | F F | F | F F | unknown | F
AnnotateOpTraitsProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.metainfo.annotation
 
AnnotateOpTraitsProcCtx(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.AnnotateOpTraitsProcCtx
 
AnnotateStatsProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.stats.annotation
 
AnnotateStatsProcCtx(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.stats.annotation.AnnotateStatsProcCtx
 
AnnotateWithOpTraits - Class in org.apache.hadoop.hive.ql.optimizer.metainfo.annotation
 
AnnotateWithOpTraits() - Constructor for class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.AnnotateWithOpTraits
 
AnnotateWithStatistics - Class in org.apache.hadoop.hive.ql.optimizer.stats.annotation
 
AnnotateWithStatistics() - Constructor for class org.apache.hadoop.hive.ql.optimizer.stats.annotation.AnnotateWithStatistics
 
append(Object) - Method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
append(Writable) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Writer
Append a row of values.
apply(T) - Method in interface org.apache.hadoop.hive.ql.exec.NodeUtils.Function
 
apply(T) - Method in class org.apache.hadoop.hive.ql.exec.PTFUtils.Predicate
 
apply(RelOptCluster, RelOptSchema, SchemaPlus) - Method in class org.apache.hadoop.hive.ql.optimizer.CostBasedOptimizer
 
applyAuthorizationConfigPolicy(HiveConf) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessController
 
applyAuthorizationConfigPolicy(HiveConf) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
Modify the given HiveConf object to configure authorization related parameters or other parameters related to hive security
applyAuthorizationConfigPolicy(HiveConf) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
applyAuthorizationConfigPolicy(HiveConf) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
applyAuthorizationPolicy() - Method in class org.apache.hadoop.hive.ql.session.SessionState
If authorization mode is v2, then pass it through authorizer so that it can apply any security configuration changes.
ArchiveDesc - Class in org.apache.hadoop.hive.ql.plan
ArchiveDesc.
ArchiveDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ArchiveDesc
 
ArchiveUtils - Class in org.apache.hadoop.hive.ql.exec
ArchiveUtils.
ArchiveUtils() - Constructor for class org.apache.hadoop.hive.ql.exec.ArchiveUtils
 
ArchiveUtils.HarPathHelper - Class in org.apache.hadoop.hive.ql.exec
HarPathHelper helps to create har:/ URIs for locations inside of archive.
ArchiveUtils.HarPathHelper(HiveConf, URI, URI) - Constructor for class org.apache.hadoop.hive.ql.exec.ArchiveUtils.HarPathHelper
Creates helper for archive.
ArchiveUtils.PartSpecInfo - Class in org.apache.hadoop.hive.ql.exec
PartSpecInfo keeps fields and values extracted from partial partition info which is prefix of the full info.
ArchiveWork - Class in org.apache.hadoop.hive.ql.plan
ArchiveWork.
ArchiveWork() - Constructor for class org.apache.hadoop.hive.ql.plan.ArchiveWork
 
ArchiveWork.ArchiveActionType - Enum in org.apache.hadoop.hive.ql.plan
 
ARCHIVING_LEVEL - Static variable in class org.apache.hadoop.hive.ql.exec.ArchiveUtils
 
arg0Type(ExprNodeGenericFuncDesc) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
ARRAY - Static variable in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe
 
array() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
arrayList() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
ArrayWritableGroupConverter - Class in org.apache.hadoop.hive.ql.io.parquet.convert
 
ArrayWritableGroupConverter(GroupType, HiveGroupConverter, int) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.convert.ArrayWritableGroupConverter
 
ArrayWritableObjectInspector - Class in org.apache.hadoop.hive.ql.io.parquet.serde
The ArrayWritableObjectInspector will inspect an ArrayWritable, considering it as a Hive struct.
It can also inspect a List if Hive decides to inspect the result of an inspection.
ArrayWritableObjectInspector(StructTypeInfo) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
AS - Static variable in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
assertNoMissingPrivilege(Collection<SQLPrivTypeGrant>, HivePrincipal, HivePrivilegeObject) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLAuthorizationUtils
 
assign(VectorExpressionWriter[], List<ObjectInspector>) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory.ListOIDClosure
 
assign(VectorExpressionWriter[], ObjectInspector) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory.SingleOIDClosure
 
assignDecimal(int, Decimal128) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
assignDouble(int, double) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
assignLong(int, long) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
assignNullDecimal(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
assignNullDouble(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
assignNullLong(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
assignNullString(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
assignObjectValue(Object, int) - Method in interface org.apache.hadoop.hive.ql.exec.vector.VectorColumnAssign
 
assignString(int, byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
assignTimeInNanoSec(long, Timestamp) - Static method in class org.apache.hadoop.hive.ql.exec.vector.TimestampUtils
Store the given timestamp in nanoseconds into the timestamp object.
assignVectorValue(VectorizedRowBatch, int, int, int) - Method in interface org.apache.hadoop.hive.ql.exec.vector.VectorColumnAssign
 
ASTConverter - Class in org.apache.hadoop.hive.ql.optimizer.optiq.translator
 
ASTErrorNode - Class in org.apache.hadoop.hive.ql.parse
 
ASTErrorNode(TokenStream, Token, Token, RecognitionException) - Constructor for class org.apache.hadoop.hive.ql.parse.ASTErrorNode
 
ASTNode - Class in org.apache.hadoop.hive.ql.parse
 
ASTNode() - Constructor for class org.apache.hadoop.hive.ql.parse.ASTNode
 
ASTNode(Token) - Constructor for class org.apache.hadoop.hive.ql.parse.ASTNode
Constructor.
ASTNode(ASTNode) - Constructor for class org.apache.hadoop.hive.ql.parse.ASTNode
 
ASTNodeOrigin - Class in org.apache.hadoop.hive.ql.parse
ASTNodeOrigin contains contextual information about the object from whose definition a particular ASTNode originated.
ASTNodeOrigin(String, String, String, String, ASTNode) - Constructor for class org.apache.hadoop.hive.ql.parse.ASTNodeOrigin
 
ATSHook - Class in org.apache.hadoop.hive.ql.hooks
ATSHook sends query + plan info to Ambari Timeline Server
ATSHook() - Constructor for class org.apache.hadoop.hive.ql.hooks.ATSHook
 
augmentPlan() - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
augmentPlan() - Method in class org.apache.hadoop.hive.ql.exec.Operator
Called during semantic analysis as operators are being added in order to give them a chance to compute any additional plan information needed.
AuthorizationException - Exception in org.apache.hadoop.hive.ql.metadata
 
AuthorizationException() - Constructor for exception org.apache.hadoop.hive.ql.metadata.AuthorizationException
 
AuthorizationException(String) - Constructor for exception org.apache.hadoop.hive.ql.metadata.AuthorizationException
Constructs an AuthorizationException with the specified detail message.
AuthorizationException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.metadata.AuthorizationException
Constructs an AuthorizationException with the specified cause.
AuthorizationException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.ql.metadata.AuthorizationException
 
AuthorizationParseUtils - Class in org.apache.hadoop.hive.ql.parse.authorization
Utility functions for creating objects relevant for authorization operations from AST
AuthorizationParseUtils() - Constructor for class org.apache.hadoop.hive.ql.parse.authorization.AuthorizationParseUtils
 
AuthorizationPreEventListener - Class in org.apache.hadoop.hive.ql.security.authorization
AuthorizationPreEventListener : A MetaStorePreEventListener that performs authorization/authentication checks on the metastore-side.
AuthorizationPreEventListener(Configuration) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.AuthorizationPreEventListener
 
AuthorizationPreEventListener.PartitionWrapper - Class in org.apache.hadoop.hive.ql.security.authorization
 
AuthorizationPreEventListener.PartitionWrapper(Table, Partition) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.AuthorizationPreEventListener.PartitionWrapper
 
AuthorizationPreEventListener.PartitionWrapper(Partition, PreEventContext) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.AuthorizationPreEventListener.PartitionWrapper
 
AuthorizationPreEventListener.TableWrapper - Class in org.apache.hadoop.hive.ql.security.authorization
 
AuthorizationPreEventListener.TableWrapper(Table) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.AuthorizationPreEventListener.TableWrapper
 
AuthorizationUtils - Class in org.apache.hadoop.hive.ql.security.authorization
Utility code shared by hive internal code and sql standard authorization plugin implementation
AuthorizationUtils() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
 
authorize(Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.BitSetCheckedAuthorizationProvider
 
authorize(Database, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.BitSetCheckedAuthorizationProvider
 
authorize(Table, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.BitSetCheckedAuthorizationProvider
 
authorize(Partition, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.BitSetCheckedAuthorizationProvider
 
authorize(Table, Partition, List<String>, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.BitSetCheckedAuthorizationProvider
 
authorize(Privilege[], Privilege[]) - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
Authorization user level privileges.
authorize(Database, Privilege[], Privilege[]) - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
Authorization privileges against a database object.
authorize(Table, Privilege[], Privilege[]) - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
Authorization privileges against a hive table object.
authorize(Partition, Privilege[], Privilege[]) - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
Authorization privileges against a hive partition object.
authorize(Table, Partition, List<String>, Privilege[], Privilege[]) - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
Authorization privileges against a list of columns.
authorize(Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider
 
authorize(Database, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider
 
authorize(Table, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider
 
authorize(Partition, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider
 
authorize(Table, Partition, List<String>, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider
 
authorize(Path, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider
Authorization privileges against a path.
authorizeAndGetRevokePrivileges(List<HivePrincipal>, List<HivePrivilege>, HivePrivilegeObject, boolean, IMetaStoreClient, String) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.RevokePrivAuthUtils
 
AutoProgressor - Class in org.apache.hadoop.hive.ql.exec
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.
available() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
AvgPartitionSizeBasedBigTableSelectorForAutoSMJ - Class in org.apache.hadoop.hive.ql.optimizer
 
AvgPartitionSizeBasedBigTableSelectorForAutoSMJ() - Constructor for class org.apache.hadoop.hive.ql.optimizer.AvgPartitionSizeBasedBigTableSelectorForAutoSMJ
 
AvroContainerInputFormat - Class in org.apache.hadoop.hive.ql.io.avro
 
AvroContainerInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.avro.AvroContainerInputFormat
 
AvroContainerOutputFormat - Class in org.apache.hadoop.hive.ql.io.avro
Write to an Avro file from a Hive process.
AvroContainerOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.avro.AvroContainerOutputFormat
 
AvroGenericRecordReader - Class in org.apache.hadoop.hive.ql.io.avro
RecordReader optimized against Avro GenericRecords that returns to record as the value of the k-v pair, as Hive requires.
AvroGenericRecordReader(JobConf, FileSplit, Reporter) - Constructor for class org.apache.hadoop.hive.ql.io.avro.AvroGenericRecordReader
 
AvroGenericRecordWriter - Class in org.apache.hadoop.hive.ql.io.avro
Write an Avro GenericRecord to an Avro data file.
AvroGenericRecordWriter(DataFileWriter<GenericRecord>) - Constructor for class org.apache.hadoop.hive.ql.io.avro.AvroGenericRecordWriter
 

B

backtrack(List<ExprNodeDesc>, Operator<?>, Operator<?>) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
Convert expressions in current operator to those in terminal operator, which is an ancestor of current or null (back to top operator).
backtrack(ExprNodeDesc, Operator<?>, Operator<?>) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
 
BACKUP_COMMON_JOIN - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
BACKUP_PREFIX - Static variable in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileMergeMapper
 
BACKUP_PREFIX - Static variable in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateMapper
 
backupOutputPath(FileSystem, Path, JobConf) - Static method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileMergeMapper
 
backupOutputPath(FileSystem, Path, JobConf) - Static method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateMapper
 
BASE_PREFIX - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
BaseSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
BaseSemanticAnalyzer.
BaseSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
BaseSemanticAnalyzer(HiveConf, Hive) - Constructor for class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
BaseSemanticAnalyzer.tableSpec - Class in org.apache.hadoop.hive.ql.parse
tableSpec.
BaseSemanticAnalyzer.tableSpec(Hive, HiveConf, ASTNode) - Constructor for class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
BaseSemanticAnalyzer.tableSpec(Hive, HiveConf, ASTNode, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
BaseSemanticAnalyzer.tableSpec.SpecType - Enum in org.apache.hadoop.hive.ql.parse
 
BaseWork - Class in org.apache.hadoop.hive.ql.plan
BaseWork.
BaseWork() - Constructor for class org.apache.hadoop.hive.ql.plan.BaseWork
 
BaseWork(String) - Constructor for class org.apache.hadoop.hive.ql.plan.BaseWork
 
between(String, Object, Object) - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Builder
Add a between leaf to the current item on the stack.
BigDecimalWritable - Class in org.apache.hadoop.hive.ql.io.parquet.writable
This file is taken from a patch to hive 0.11 Issue : https://issues.apache.org/jira/browse/HIVE-2693
BigDecimalWritable() - Constructor for class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
BigDecimalWritable(byte[], int) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
BigDecimalWritable(BigDecimalWritable) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
BigDecimalWritable(BigDecimal) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
BigTableSelectorForAutoSMJ - Interface in org.apache.hadoop.hive.ql.optimizer
 
BinaryColumnStatistics - Interface in org.apache.hadoop.hive.ql.io.orc
Statistics for binary columns.
binaryEvaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcat
 
BinaryRecordReader - Class in org.apache.hadoop.hive.ql.exec
Read from a binary stream and treat each 1000 bytes (configurable via hive.binary.record.max.length) as a record.
BinaryRecordReader() - Constructor for class org.apache.hadoop.hive.ql.exec.BinaryRecordReader
 
BinaryWritable - Class in org.apache.hadoop.hive.ql.io.parquet.writable
A Wrapper to support constructor with Binary and String TODO : remove it, and call BytesWritable with the getBytes() in HIVE-6366
BinaryWritable(Binary) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.writable.BinaryWritable
 
BinaryWritable.DicBinaryWritable - Class in org.apache.hadoop.hive.ql.io.parquet.writable
 
BinaryWritable.DicBinaryWritable(Binary, String) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.writable.BinaryWritable.DicBinaryWritable
 
BitmapIndexHandler - Class in org.apache.hadoop.hive.ql.index.bitmap
Index handler for the bitmap index.
BitmapIndexHandler() - Constructor for class org.apache.hadoop.hive.ql.index.bitmap.BitmapIndexHandler
 
BitmapInnerQuery - Class in org.apache.hadoop.hive.ql.index.bitmap
Representation of inner bitmap index SELECT query that scans bitmap index tables for a pushed predicate
BitmapInnerQuery(String, ExprNodeDesc, String) - Constructor for class org.apache.hadoop.hive.ql.index.bitmap.BitmapInnerQuery
 
BitmapObjectInput - Class in org.apache.hadoop.hive.ql.index.bitmap
An ObjectInput that allows for conversion from an List of LongWritable to an EWAH-compressed bitmap.
BitmapObjectInput() - Constructor for class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
BitmapObjectInput(List<LongWritable>) - Constructor for class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
BitmapObjectOutput - Class in org.apache.hadoop.hive.ql.index.bitmap
An ObjectOutput that allows conversion from an EWAH-compressed bitmap to an List of LongWritable.
BitmapObjectOutput() - Constructor for class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
BitmapOuterQuery - Class in org.apache.hadoop.hive.ql.index.bitmap
Representation of the outer query on bitmap indexes that JOINs the result of inner SELECT scans on bitmap indexes (represented in BitmapQuery objects) using EWAH_* bitwise operations
BitmapOuterQuery(String, BitmapQuery, BitmapQuery) - Constructor for class org.apache.hadoop.hive.ql.index.bitmap.BitmapOuterQuery
 
BitmapQuery - Interface in org.apache.hadoop.hive.ql.index.bitmap
Generic interface to representations of queries on bitmap indexes
BitSetCheckedAuthorizationProvider - Class in org.apache.hadoop.hive.ql.security.authorization
 
BitSetCheckedAuthorizationProvider() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.BitSetCheckedAuthorizationProvider
 
BLOCK_MISSING_MESSAGE - Static variable in class org.apache.hadoop.hive.ql.io.RCFile
 
BLOCK_PADDING - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcFile
Deprecated. 
BlockMergeTask - Class in org.apache.hadoop.hive.ql.io.rcfile.merge
 
BlockMergeTask() - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.merge.BlockMergeTask
 
BLOCKOFFSET - Static variable in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
blockPadding(boolean) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
Sets whether the HDFS blocks are padded to prevent stripes from straddling blocks.
BooleanColumnStatistics - Interface in org.apache.hadoop.hive.ql.io.orc
Statistics for boolean columns.
BOTH_PROJECT - Static variable in class org.apache.hadoop.hive.ql.optimizer.optiq.rules.HivePullUpProjectsAboveJoinRule
 
BoundaryDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
BoundaryDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.BoundaryDef
 
bucket(int) - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
The bucket that is included in this file.
BUCKET_DIGIT_PATTERN - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
BUCKET_DIGITS - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
BUCKET_PREFIX - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
bucketFileFilter - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
BucketingSortingCtx - Class in org.apache.hadoop.hive.ql.optimizer.physical
This class contains the bucketing sorting context that is passed while walking the operator tree in inferring bucket/sort columns.
BucketingSortingCtx(boolean) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx
 
BucketingSortingCtx.BucketCol - Class in org.apache.hadoop.hive.ql.optimizer.physical
BucketCol.
BucketingSortingCtx.BucketCol(String, int) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.BucketCol
 
BucketingSortingCtx.BucketCol() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.BucketCol
 
BucketingSortingCtx.BucketSortCol - Interface in org.apache.hadoop.hive.ql.optimizer.physical
BucketSortCol.
BucketingSortingCtx.SortCol - Class in org.apache.hadoop.hive.ql.optimizer.physical
SortCol.
BucketingSortingCtx.SortCol() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.SortCol
 
BucketingSortingCtx.SortCol(String, int, char) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.SortCol
 
BucketingSortingCtx.SortCol(char) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.SortCol
 
BucketingSortingInferenceOptimizer - Class in org.apache.hadoop.hive.ql.optimizer.physical
BucketingSortingInferenceOptimizer.
BucketingSortingInferenceOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingInferenceOptimizer
 
BucketingSortingOpProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.physical
Operator factory for the rule processors for inferring bucketing/sorting columns.
BucketingSortingOpProcFactory() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory
 
BucketingSortingOpProcFactory.DefaultInferrer - Class in org.apache.hadoop.hive.ql.optimizer.physical
 
BucketingSortingOpProcFactory.DefaultInferrer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.DefaultInferrer
 
BucketingSortingOpProcFactory.ExtractInferrer - Class in org.apache.hadoop.hive.ql.optimizer.physical
Processor for Extract operator.
BucketingSortingOpProcFactory.ExtractInferrer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.ExtractInferrer
 
BucketingSortingOpProcFactory.FileSinkInferrer - Class in org.apache.hadoop.hive.ql.optimizer.physical
Processor for FileSink operator.
BucketingSortingOpProcFactory.FileSinkInferrer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.FileSinkInferrer
 
BucketingSortingOpProcFactory.ForwardingInferrer - Class in org.apache.hadoop.hive.ql.optimizer.physical
Filter processor
BucketingSortingOpProcFactory.ForwardingInferrer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.ForwardingInferrer
 
BucketingSortingOpProcFactory.GroupByInferrer - Class in org.apache.hadoop.hive.ql.optimizer.physical
Processor for GroupBy operator.
BucketingSortingOpProcFactory.GroupByInferrer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.GroupByInferrer
 
BucketingSortingOpProcFactory.JoinInferrer - Class in org.apache.hadoop.hive.ql.optimizer.physical
Processor for Join Operator.
BucketingSortingOpProcFactory.JoinInferrer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.JoinInferrer
 
BucketingSortingOpProcFactory.MultiGroupByInferrer - Class in org.apache.hadoop.hive.ql.optimizer.physical
Processor for GroupByOperator, the special case where it follows a ForwardOperator There is a multi group by optimization which puts multiple group by operators in a reducer when they share the same keys and are part of a multi insert query.
BucketingSortingOpProcFactory.MultiGroupByInferrer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.MultiGroupByInferrer
 
BucketingSortingOpProcFactory.SelectInferrer - Class in org.apache.hadoop.hive.ql.optimizer.physical
Processor for Select operator.
BucketingSortingOpProcFactory.SelectInferrer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.SelectInferrer
 
BucketingSortingReduceSinkOptimizer - Class in org.apache.hadoop.hive.ql.optimizer
This transformation does optimization for enforcing bucketing and sorting.
BucketingSortingReduceSinkOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.BucketingSortingReduceSinkOptimizer
 
BucketingSortingReduceSinkOptimizer.BucketSortReduceSinkProcessor - Class in org.apache.hadoop.hive.ql.optimizer
BucketSortReduceSinkProcessor.
BucketingSortingReduceSinkOptimizer.BucketSortReduceSinkProcessor(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.BucketingSortingReduceSinkOptimizer.BucketSortReduceSinkProcessor
 
BucketizedHiveInputFormat<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
BucketizedHiveInputFormat serves the similar function as hiveInputFormat but its getSplits() always group splits from one input file into one wrapper split.
BucketizedHiveInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.BucketizedHiveInputFormat
 
BucketizedHiveInputSplit - Class in org.apache.hadoop.hive.ql.io
HiveInputSplit encapsulates an InputSplit with its corresponding inputFormatClass.
BucketizedHiveInputSplit() - Constructor for class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
BucketizedHiveInputSplit(InputSplit[], String) - Constructor for class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
BucketizedHiveRecordReader<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
BucketizedHiveRecordReader is a wrapper on a list of RecordReader.
BucketizedHiveRecordReader(InputFormat, BucketizedHiveInputSplit, JobConf, Reporter) - Constructor for class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
BucketJoinProcCtx - Class in org.apache.hadoop.hive.ql.optimizer
 
BucketJoinProcCtx(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
BucketMapJoinContext - Class in org.apache.hadoop.hive.ql.plan
was inner class of MapreLocalWork.
BucketMapJoinContext() - Constructor for class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
BucketMapJoinContext(MapJoinDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
BucketMapJoinOptimizer - Class in org.apache.hadoop.hive.ql.optimizer
this transformation does bucket map join optimization.
BucketMapJoinOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.BucketMapJoinOptimizer
 
BucketMapjoinProc - Class in org.apache.hadoop.hive.ql.optimizer
 
BucketMapjoinProc(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.BucketMapjoinProc
 
BucketMatcher - Interface in org.apache.hadoop.hive.ql.exec
 
bufferSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
 
bufferSize(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
The size of the memory buffers used for compressing and storing the stripe in memory.
build() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Builder
 
build() - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Builder
Build and return the SearchArgument that has been defined.
build() - Method in class org.apache.hadoop.hive.ql.metadata.formatting.MapBuilder
 
buildAssigners(VectorizedRowBatch) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnAssignFactory
 
buildAssigners(VectorizedRowBatch, ObjectInspector, Map<String, Integer>, List<String>) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnAssignFactory
Builds the assigners from an object inspector and from a list of columns.
buildAST(SqlOperator, List<ASTNode>) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.translator.SqlFunctionConverter
 
buildAST(SqlOperator, List<ASTNode>, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.translator.SqlFunctionConverter
Build AST for flattened Associative expressions ('and', 'or').
buildExpressionDef(ShapeDetails, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
buildObjectAssign(VectorizedRowBatch, int, ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorColumnAssignFactory
 
byName(String) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.Version
 
BytesColumnVector - Class in org.apache.hadoop.hive.ql.exec.vector
This class supports string and binary data by value reference -- i.e.
BytesColumnVector() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
Use this constructor for normal operation.
BytesColumnVector(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
Don't call this constructor except for testing purposes.
ByteWritable - Class in org.apache.hadoop.hive.ql.exec
ByteWritable.
ByteWritable(int) - Constructor for class org.apache.hadoop.hive.ql.exec.ByteWritable
 
ByteWritable() - Constructor for class org.apache.hadoop.hive.ql.exec.ByteWritable
 
ByteWritable.Comparator - Class in org.apache.hadoop.hive.ql.exec
A Comparator optimized for BytesWritable.
ByteWritable.Comparator() - Constructor for class org.apache.hadoop.hive.ql.exec.ByteWritable.Comparator
 

C

C - Static variable in class org.apache.hadoop.hive.ql.exec.PartitionKeySampler
 
cache(String, Object) - Method in class org.apache.hadoop.hive.ql.exec.mr.ObjectCache
 
cache(String, Object) - Method in interface org.apache.hadoop.hive.ql.exec.ObjectCache
Add an object to the cache
cache(String, Object) - Method in class org.apache.hadoop.hive.ql.exec.tez.ObjectCache
 
calculateListBucketingLevel() - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
Calculate list bucketing level.
calculateSkewedValueSubDirList() - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
Calculate skewed value subdirectory directory which is used in FileSinkOperator.java createKeyForStatsPublisher() For example, create table test skewed by (key, value) on (('484','val_484') stored as DIRECTORIES; after the method, skewedValuesDirNames will contain 2 elements: key=484/value=val_484 HIVE_LIST_BUCKETING_DEFAULT_DIR_NAME/HIVE_LIST_BUCKETING_DEFAULT_DIR_NAME
callback(OrcFile.WriterCallback) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
Add a listener for when the stripe and file are about to be closed.
canApplyOnFilterOperator() - Static method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyProcFactory
 
canApplyOnGroupByOperator() - Static method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyProcFactory
 
canApplyOnSelectOperator() - Static method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyProcFactory
 
canBeMerged() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
cancelDelegationToken(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
canDownloadResource(String) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
Returns true if it is from any external File Systems except local
canDrop() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
canDrop() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
canHandleOpTree(Operator, HiveConf, QueryProperties) - Static method in class org.apache.hadoop.hive.ql.optimizer.CostBasedOptimizer
 
cannotConvert(long, long, long) - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.CommonJoinTaskDispatcher
 
canWrite() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
canWrite() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
carriageReturnCode - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
carryForwardNames() - Method in class org.apache.hadoop.hive.ql.udf.ptf.Noop.NoopResolver
 
carryForwardNames() - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMap.NoopWithMapResolver
 
carryForwardNames() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
 
carryForwardNames() - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.WindowingTableFunctionResolver
 
CastBooleanToStringViaLongToString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
CastBooleanToStringViaLongToString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToStringViaLongToString
 
CastBooleanToStringViaLongToString(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastBooleanToStringViaLongToString
 
CastDateToString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
CastDateToString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToString
 
CastDateToString(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDateToString
 
CastDecimalToBoolean - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Type cast decimal to boolean
CastDecimalToBoolean() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToBoolean
 
CastDecimalToBoolean(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToBoolean
 
CastDecimalToDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Cast a decimal to a decimal, accounting for precision and scale changes.
CastDecimalToDecimal(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToDecimal
 
CastDecimalToDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToDecimal
 
CastDecimalToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
CastDecimalToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToDouble
 
CastDecimalToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToDouble
 
CastDecimalToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Type cast decimal to long
CastDecimalToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToLong
 
CastDecimalToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToLong
 
CastDecimalToString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
To support vectorized cast of decimal to string.
CastDecimalToString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToString
 
CastDecimalToString(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToString
 
CastDecimalToTimestamp - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Type cast decimal to timestamp.
CastDecimalToTimestamp(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToTimestamp
 
CastDecimalToTimestamp() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToTimestamp
 
CastDoubleToDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Cast input double to a decimal.
CastDoubleToDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDoubleToDecimal
 
CastDoubleToDecimal(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDoubleToDecimal
 
CastLongToDate - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Casts a timestamp and date vector to a date vector.
CastLongToDate() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToDate
 
CastLongToDate(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToDate
 
CastLongToDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
To be used to cast long and boolean to decimal.
CastLongToDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToDecimal
 
CastLongToDecimal(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToDecimal
 
CastLongToString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
CastLongToString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToString
 
CastLongToString(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToString
 
CastStringToDate - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Casts a string vector to a date vector.
CastStringToDate() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDate
 
CastStringToDate(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDate
 
CastStringToDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Cast a string to a decimal.
CastStringToDecimal(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDecimal
 
CastStringToDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDecimal
 
CastTimestampToDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
To be used to cast timestamp to decimal.
CastTimestampToDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastTimestampToDecimal
 
CastTimestampToDecimal(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CastTimestampToDecimal
 
CBOTableStatsValidator - Class in org.apache.hadoop.hive.ql.optimizer.optiq.stats
 
CBOTableStatsValidator() - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.stats.CBOTableStatsValidator
 
ceiling(int, Decimal128, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
charSetString(String, String) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
check(byte[], int, int) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar.Checker
Checks whether the given string matches with its pattern.
checkBucketedTable(Table, ParseContext, PrunedPartitionList) - Method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.TableScanRule
 
checkColumn(String, String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
check if column name is already exist in RR
checkFatalErrors(Counters, StringBuilder) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
Fatal errors are those errors that cannot be recovered by retries.
checkFatalErrors(Counters, StringBuilder) - Method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
checkFatalErrors(Counters, StringBuilder) - Method in interface org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHook
 
checkFatalErrors(Counters, StringBuilder) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.BlockMergeTask
 
checkFatalErrors(Counters, StringBuilder) - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanTask
 
checkFatalErrors(Counters, StringBuilder) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateTask
 
checkInputFormat(FileSystem, HiveConf, Class<? extends InputFormat>, ArrayList<FileStatus>) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
checks if files are in same format as the given input format.
checkJobTracker(JobConf, Log) - Static method in class org.apache.hadoop.hive.ql.exec.mr.Throttle
Fetch http://tracker.om:/gc.jsp?threshold=period.
checkMapJoin(int, JoinCondDesc[]) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
checkMemoryStatus(long, long) - Method in class org.apache.hadoop.hive.ql.exec.mapjoin.MapJoinMemoryExhaustionHandler
Throws MapJoinMemoryExhaustionException when the JVM has consumed the configured percentage of memory.
checkMetastore(String, String, List<? extends Map<String, String>>, CheckResult) - Method in class org.apache.hadoop.hive.ql.metadata.HiveMetaStoreChecker
Check the metastore for inconsistencies, data missing in either the metastore or on the dfs.
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hive.ql.io.avro.AvroContainerOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hive.ql.io.HiveOutputFormatImpl
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hive.ql.io.HivePassThroughOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hive.ql.io.parquet.MapredParquetOutputFormat
 
checkPartitionsCoveredByIndex(TableScanOperator, ParseContext, Map<Table, List<Index>>) - Static method in class org.apache.hadoop.hive.ql.optimizer.IndexUtils
Check the partitions used by the table scan to make sure they also exist in the index table.
checkPrecisionOverflow(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.DecimalColumnVector
Check if the value at position i fits in the available precision, and convert the value to NULL if it does not.
checkPrivileges(HiveOperationType, List<HivePrivilegeObject>, List<HivePrivilegeObject>) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizationValidator
Check if current user has privileges to perform given operation type hiveOpType on the given input and output objects
checkPrivileges(HiveOperationType, List<HivePrivilegeObject>, List<HivePrivilegeObject>) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
Check if user has privileges to do this action on these objects
checkPrivileges(HiveOperationType, List<HivePrivilegeObject>, List<HivePrivilegeObject>) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
checkPrivileges(HiveOperationType, List<HivePrivilegeObject>, List<HivePrivilegeObject>) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAuthorizationValidator
 
checkQuerySize(long, HiveConf) - Method in class org.apache.hadoop.hive.ql.index.AbstractIndexHandler
 
checkQuerySize(long, HiveConf) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapIndexHandler
 
checkQuerySize(long, HiveConf) - Method in class org.apache.hadoop.hive.ql.index.compact.CompactIndexHandler
 
checkQuerySize(long, HiveConf) - Method in interface org.apache.hadoop.hive.ql.index.HiveIndexHandler
Check the size of an input query to make sure it fits within the bounds
CheckResult - Class in org.apache.hadoop.hive.ql.metadata
Result class used by the HiveMetaStoreChecker.
CheckResult() - Constructor for class org.apache.hadoop.hive.ql.metadata.CheckResult
 
CheckResult.PartitionResult - Class in org.apache.hadoop.hive.ql.metadata
A basic description of a partition that is missing from either the fs or the ms.
CheckResult.PartitionResult() - Constructor for class org.apache.hadoop.hive.ql.metadata.CheckResult.PartitionResult
 
checkValidity() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
childErr - Variable in class org.apache.hadoop.hive.ql.session.SessionState
Error output from any child process(es).
childOut - Variable in class org.apache.hadoop.hive.ql.session.SessionState
Standard output from any child process(es).
childToWorkMap - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
CLASS_NAME - Static variable in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
CLASS_NAME - Static variable in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
 
clean(HiveConf) - Static method in class org.apache.hadoop.hive.ql.processors.CommandProcessorFactory
 
Cleaner - Class in org.apache.hadoop.hive.ql.txn.compactor
A class to clean directories after compactions.
Cleaner() - Constructor for class org.apache.hadoop.hive.ql.txn.compactor.Cleaner
 
cleanUp(String) - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsAggregator
 
cleanUp(String) - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsAggregatorTez
 
cleanUp(String) - Method in class org.apache.hadoop.hive.ql.stats.fs.FSStatsAggregator
 
cleanUp(String) - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsAggregator
 
cleanUp(String) - Method in interface org.apache.hadoop.hive.ql.stats.StatsAggregator
This method is called after all statistics have been aggregated.
cleanUpInputFileChanged() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
cleanUpInputFileChangedOp() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
cleanUpInputFileChangedOp() - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
cleanUpInputFileChangedOp() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
cleanUpInputFileChangedOp() - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
cleanUpInputFileChangedOp() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
cleanupScratchDir() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
clear() - Method in class org.apache.hadoop.hive.ql.Context
 
clear() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
clear() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
clear() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer
 
clear() - Method in class org.apache.hadoop.hive.ql.exec.Stat
 
clear() - Static method in class org.apache.hadoop.hive.ql.io.IOContext
 
clear() - Method in class org.apache.hadoop.hive.ql.io.IOPrepareCache
 
clear(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
clear() - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx.Index
 
clear() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
clearAggregationExprsForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
clearAllowedColumnNames() - Method in class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
Clears the set of column names allowed in comparisons.
clearColumnBuffer() - Method in class org.apache.hadoop.hive.ql.io.RCFile.ValueBuffer
 
clearDistinctFuncExprsForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
clearFetch() - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
Clear the Fetch Operator.
clearFetchContext() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
Clear the context, if anything needs to be done.
clearRows() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer
Remove all elements in the RowContainer.
clearRows() - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
clearRows() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
Remove all elements in the RowContainer.
clearRows() - Method in class org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer
 
clearRows() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
Remove all elements in the RowContainer.
clearSerDeInfo() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
clearWork(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
clearWorkMap() - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
ClientStatsPublisher - Interface in org.apache.hadoop.hive.ql.stats
 
clone() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
clone() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
clone() - Method in class org.apache.hadoop.hive.ql.io.orc.Reader.Options
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.DummyStoreDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnListDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeNullDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc.sampleDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.ForwardDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
clone() - Method in interface org.apache.hadoop.hive.ql.plan.OperatorDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.SelectDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
CLONE_PLAN - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
clonedReduceSinks - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
cloneGenericUDF(GenericUDF) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Create a copy of an existing GenericUDF.
cloneGenericUDTF(GenericUDTF) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Create a copy of an existing GenericUDTF.
cloneOp() - Method in class org.apache.hadoop.hive.ql.exec.Operator
Clones only the operator.
cloneOperatorTree(Configuration, Set<Operator<?>>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
clonePlan(MapredWork) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Clones using the powers of XML.
cloneRecursiveChildren() - Method in class org.apache.hadoop.hive.ql.exec.Operator
Recursively clones all the children of the tree, Fixes the pointers to children, parents and the pointers to itself coming from the children.
cloneSd(Table) - Static method in class org.apache.hadoop.hive.ql.metadata.Partition
We already have methods that clone stuff using XML or Kryo.
close() - Method in class org.apache.hadoop.hive.ql.Driver
 
close() - Method in class org.apache.hadoop.hive.ql.exec.BinaryRecordReader
 
close() - Method in class org.apache.hadoop.hive.ql.exec.DefaultFetchFormatter
 
close() - Method in class org.apache.hadoop.hive.ql.exec.FetchFormatter.ThriftFormatter
 
close(boolean) - Method in interface org.apache.hadoop.hive.ql.exec.FileSinkOperator.RecordWriter
 
close() - Static method in class org.apache.hadoop.hive.ql.exec.MapredContext
 
close() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapper
 
close() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecReducer
 
close(boolean) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
close() - Method in class org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer
 
close() - Method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
close() - Method in interface org.apache.hadoop.hive.ql.exec.RecordReader
 
close() - Method in interface org.apache.hadoop.hive.ql.exec.RecordWriter
 
close(boolean) - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
close(boolean) - Method in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
close() - Method in class org.apache.hadoop.hive.ql.exec.TextRecordReader
 
close() - Method in class org.apache.hadoop.hive.ql.exec.TextRecordWriter
 
close() - Method in class org.apache.hadoop.hive.ql.exec.tez.HivePreWarmProcessor
 
close() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezProcessor
 
close(TezSessionState) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
close(boolean) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
Close a tez session.
close() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
close() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
close() - Method in class org.apache.hadoop.hive.ql.io.avro.AvroGenericRecordReader
 
close(boolean) - Method in class org.apache.hadoop.hive.ql.io.avro.AvroGenericRecordWriter
 
close() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
 
close() - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
close(boolean) - Method in class org.apache.hadoop.hive.ql.io.HivePassThroughRecordWriter
 
close() - Method in class org.apache.hadoop.hive.ql.io.NullRowsInputFormat.NullRowsRecordReader
 
close() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRawRecordMerger
 
close(boolean) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater
 
close() - Method in interface org.apache.hadoop.hive.ql.io.orc.RecordReader
Release the resources associated with the given reader.
close() - Method in interface org.apache.hadoop.hive.ql.io.orc.Writer
Flush all of the buffers and close the file.
close() - Method in class org.apache.hadoop.hive.ql.io.parquet.read.ParquetRecordReaderWrapper
 
close(Reporter) - Method in class org.apache.hadoop.hive.ql.io.parquet.write.ParquetRecordWriterWrapper
 
close(boolean) - Method in class org.apache.hadoop.hive.ql.io.parquet.write.ParquetRecordWriterWrapper
 
close() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeRecordReader
 
close() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileMergeMapper
 
close() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Close the reader.
close() - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanMapper
 
close() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateMapper
 
close() - Method in class org.apache.hadoop.hive.ql.io.RCFile.ValueBuffer
 
close() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Writer
 
close() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
close(boolean) - Method in interface org.apache.hadoop.hive.ql.io.RecordUpdater
Close this updater.
close() - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
close() - Method in class org.apache.hadoop.hive.ql.lockmgr.DbLockManager
 
close() - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
close() - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
close() - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
close(Log, QueryPlan) - Method in class org.apache.hadoop.hive.ql.log.PerfLogger
Call this function at the end of processing a query (any time after the last call to PerfLogEnd for a given query) to run any cleanup/final steps that need to be run
close() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
close() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Close GenericUDFEvaluator.
close() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
Close GenericUDF.
close() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTF
Called to notify the UDTF that there are no more rows to process.
close() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFExplode
 
close() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFInline
 
close() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFJSONTuple
 
close() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFParseUrlTuple
 
close() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFPosExplode
 
close() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFStack
 
close() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
close() - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
closeConnection() - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsAggregator
 
closeConnection() - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsAggregatorTez
 
closeConnection() - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsPublisher
 
closeConnection() - Method in class org.apache.hadoop.hive.ql.stats.fs.FSStatsAggregator
 
closeConnection() - Method in class org.apache.hadoop.hive.ql.stats.fs.FSStatsPublisher
 
closeConnection() - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsAggregator
 
closeConnection() - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsPublisher
 
closeConnection() - Method in interface org.apache.hadoop.hive.ql.stats.StatsAggregator
This method closes the connection to the temporary storage.
closeConnection() - Method in interface org.apache.hadoop.hive.ql.stats.StatsPublisher
This method closes the connection to the temporary storage.
closeCurrent() - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
All done.
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
We need to forward all the aggregations to children.
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.HashTableDummyOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.JoinOperator
All done.
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
close extra child operators that are initialized but are not executed.
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSMBMapJoinOperator
 
closeStream() - Method in interface org.apache.hadoop.hive.ql.history.HiveHistory
Close the log file stream
closeStream() - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
 
closeTxnManager() - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveTxnManager
This call closes down the transaction manager.
closeWriters(boolean) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
 
CodecPool - Class in org.apache.hadoop.hive.ql.io
A global compressor/decompressor pool used to save and reuse (possibly native) compression/decompression codecs.
ColAndCol - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Evaluate AND of two boolean columns and store result in the output boolean column.
ColAndCol(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.ColAndCol
 
ColAndCol() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.ColAndCol
 
collect(HiveKey, Object) - Method in class org.apache.hadoop.hive.ql.exec.PartitionKeySampler
 
collect(byte[], byte[], int) - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
collect(byte[], byte[], int) - Method in interface org.apache.hadoop.hive.ql.exec.TopNHash.BinaryCollector
 
collect(Object) - Method in interface org.apache.hadoop.hive.ql.udf.generic.Collector
Other classes will call collect() with the data that it has.
collect(Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.UDTFCollector
 
CollectDesc - Class in org.apache.hadoop.hive.ql.plan
CollectDesc.
CollectDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CollectDesc
 
CollectDesc(Integer) - Constructor for class org.apache.hadoop.hive.ql.plan.CollectDesc
 
CollectOperator - Class in org.apache.hadoop.hive.ql.exec
Buffers rows emitted by other operators.
CollectOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.CollectOperator
 
Collector - Interface in org.apache.hadoop.hive.ql.udf.generic
Collector gets data from a source.
collectStatistics(HiveConf, PrunedPartitionList, Table, TableScanOperator) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Collect table, partition and column level statistics
COLON - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
ColOrCol - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This class performs OR expression on two input columns and stores, the boolean output in a separate output column.
ColOrCol(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.ColOrCol
 
ColOrCol() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.ColOrCol
 
cols - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
ColStatistics - Class in org.apache.hadoop.hive.ql.plan
 
ColStatistics(String, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ColStatistics
 
ColStatistics() - Constructor for class org.apache.hadoop.hive.ql.plan.ColStatistics
 
COLUMN_NUMBER_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.io.RCFile
 
COLUMN_NUMBER_METADATA_STR - Static variable in class org.apache.hadoop.hive.ql.io.RCFile
 
ColumnAccessAnalyzer - Class in org.apache.hadoop.hive.ql.parse
 
ColumnAccessAnalyzer() - Constructor for class org.apache.hadoop.hive.ql.parse.ColumnAccessAnalyzer
 
ColumnAccessAnalyzer(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.parse.ColumnAccessAnalyzer
 
ColumnAccessInfo - Class in org.apache.hadoop.hive.ql.parse
 
ColumnAccessInfo() - Constructor for class org.apache.hadoop.hive.ql.parse.ColumnAccessInfo
 
ColumnInfo - Class in org.apache.hadoop.hive.ql.exec
Implementation for ColumnInfo which contains the internal name for the column (the one that is used by the operator to access the column) and the type (identified by a java class).
ColumnInfo() - Constructor for class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
ColumnInfo(String, TypeInfo, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
ColumnInfo(String, Class, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
ColumnInfo(String, TypeInfo, String, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
ColumnInfo(String, ObjectInspector, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
ColumnInfo(String, ObjectInspector, String, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
ColumnInfo(ColumnInfo) - Constructor for class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
columnNamesRowResolvedCanBeObtained() - Method in class org.apache.hadoop.hive.ql.exec.FilterOperator
 
columnNamesRowResolvedCanBeObtained() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
columnNamesRowResolvedCanBeObtained() - Method in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
ColumnPruner - Class in org.apache.hadoop.hive.ql.optimizer
Implementation of one of the rule-based optimization steps.
ColumnPruner() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPruner
empty constructor.
ColumnPruner.ColumnPrunerWalker - Class in org.apache.hadoop.hive.ql.optimizer
Walks the op tree in post order fashion (skips selects with file sink or script op children).
ColumnPruner.ColumnPrunerWalker(Dispatcher) - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPruner.ColumnPrunerWalker
 
ColumnPrunerProcCtx - Class in org.apache.hadoop.hive.ql.optimizer
This class implements the processor context for Column Pruner.
ColumnPrunerProcCtx(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
 
ColumnPrunerProcFactory - Class in org.apache.hadoop.hive.ql.optimizer
Factory for generating the different node processors used by ColumnPruner.
ColumnPrunerProcFactory.ColumnPrunerDefaultProc - Class in org.apache.hadoop.hive.ql.optimizer
The Default Node Processor for Column Pruning.
ColumnPrunerProcFactory.ColumnPrunerDefaultProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerDefaultProc
 
ColumnPrunerProcFactory.ColumnPrunerFilterProc - Class in org.apache.hadoop.hive.ql.optimizer
Node Processor for Column Pruning on Filter Operators.
ColumnPrunerProcFactory.ColumnPrunerFilterProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerFilterProc
 
ColumnPrunerProcFactory.ColumnPrunerGroupByProc - Class in org.apache.hadoop.hive.ql.optimizer
Node Processor for Column Pruning on Group By Operators.
ColumnPrunerProcFactory.ColumnPrunerGroupByProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerGroupByProc
 
ColumnPrunerProcFactory.ColumnPrunerJoinProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Column Pruning on Join Operators.
ColumnPrunerProcFactory.ColumnPrunerJoinProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerJoinProc
 
ColumnPrunerProcFactory.ColumnPrunerLateralViewForwardProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Column Pruning on Lateral View Forward Operators.
ColumnPrunerProcFactory.ColumnPrunerLateralViewForwardProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerLateralViewForwardProc
 
ColumnPrunerProcFactory.ColumnPrunerLateralViewJoinProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Column Pruning on Lateral View Join Operators.
ColumnPrunerProcFactory.ColumnPrunerLateralViewJoinProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerLateralViewJoinProc
 
ColumnPrunerProcFactory.ColumnPrunerMapJoinProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Column Pruning on Map Join Operators.
ColumnPrunerProcFactory.ColumnPrunerMapJoinProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerMapJoinProc
 
ColumnPrunerProcFactory.ColumnPrunerPTFProc - Class in org.apache.hadoop.hive.ql.optimizer
- Pruning can only be done for Windowing.
ColumnPrunerProcFactory.ColumnPrunerPTFProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerPTFProc
 
ColumnPrunerProcFactory.ColumnPrunerReduceSinkProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Column Pruning on Reduce Sink Operators.
ColumnPrunerProcFactory.ColumnPrunerReduceSinkProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerReduceSinkProc
 
ColumnPrunerProcFactory.ColumnPrunerSelectProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Column Pruning on Select Operators.
ColumnPrunerProcFactory.ColumnPrunerSelectProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerSelectProc
 
ColumnPrunerProcFactory.ColumnPrunerTableScanProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Column Pruning on Table Scan Operators.
ColumnPrunerProcFactory.ColumnPrunerTableScanProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerTableScanProc
 
COLUMNS - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
COLUMNS_BUFFER_SIZE_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.io.RCFile.Writer
 
COLUMNS_TYPES - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
ColumnStatistics - Interface in org.apache.hadoop.hive.ql.io.orc
Statistics that are available for all types of columns.
ColumnStatsDesc - Class in org.apache.hadoop.hive.ql.plan
Contains the information needed to persist column level statistics
ColumnStatsDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
ColumnStatsDesc(String, String, List<String>, List<String>, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
ColumnStatsSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
ColumnStatsSemanticAnalyzer.
ColumnStatsSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.ColumnStatsSemanticAnalyzer
 
ColumnStatsSemanticAnalyzer(HiveConf, ASTNode) - Constructor for class org.apache.hadoop.hive.ql.parse.ColumnStatsSemanticAnalyzer
 
ColumnStatsTask - Class in org.apache.hadoop.hive.ql.exec
ColumnStatsTask implementation.
ColumnStatsTask() - Constructor for class org.apache.hadoop.hive.ql.exec.ColumnStatsTask
 
ColumnStatsWork - Class in org.apache.hadoop.hive.ql.plan
ColumnStats Work.
ColumnStatsWork() - Constructor for class org.apache.hadoop.hive.ql.plan.ColumnStatsWork
 
ColumnStatsWork(FetchWork, ColumnStatsDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.ColumnStatsWork
 
ColumnTruncateMapper - Class in org.apache.hadoop.hive.ql.io.rcfile.truncate
 
ColumnTruncateMapper() - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateMapper
 
ColumnTruncateTask - Class in org.apache.hadoop.hive.ql.io.rcfile.truncate
 
ColumnTruncateTask() - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateTask
 
ColumnTruncateWork - Class in org.apache.hadoop.hive.ql.io.rcfile.truncate
 
ColumnTruncateWork() - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
ColumnTruncateWork(List<Integer>, Path, Path) - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
ColumnTruncateWork(List<Integer>, Path, Path, boolean, DynamicPartitionCtx) - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
columnType - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator.BinaryStatsAgg
 
columnType - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator.BooleanStatsAgg
 
columnType - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator.DecimalStatsAgg
 
columnType - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.DoubleStatsAgg
 
columnType - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.LongStatsAgg
 
columnType - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg
 
ColumnVector - Class in org.apache.hadoop.hive.ql.exec.vector
ColumnVector contains the shared structure for the sub-types, including NULL information, and whether this vector repeats, i.e.
ColumnVector(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.ColumnVector
Constructor for super-class ColumnVector.
CombineHiveInputFormat<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
CombineHiveInputFormat is a parameterized InputFormat which looks at the path name and determine the correct InputFormat for that path name from mapredPlan.pathToPartitionInfo().
CombineHiveInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat
 
CombineHiveInputFormat.CombineHiveInputSplit - Class in org.apache.hadoop.hive.ql.io
CombineHiveInputSplit encapsulates an InputSplit with its corresponding inputFormatClassName.
CombineHiveInputFormat.CombineHiveInputSplit() - Constructor for class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
CombineHiveInputFormat.CombineHiveInputSplit(HadoopShims.InputSplitShim) - Constructor for class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
CombineHiveInputFormat.CombineHiveInputSplit(JobConf, HadoopShims.InputSplitShim) - Constructor for class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
CombineHiveRecordReader<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
CombineHiveRecordReader.
CombineHiveRecordReader(InputSplit, Configuration, Reporter, Integer) - Constructor for class org.apache.hadoop.hive.ql.io.CombineHiveRecordReader
 
CommandNeedRetryException - Exception in org.apache.hadoop.hive.ql
 
CommandNeedRetryException() - Constructor for exception org.apache.hadoop.hive.ql.CommandNeedRetryException
 
CommandNeedRetryException(String) - Constructor for exception org.apache.hadoop.hive.ql.CommandNeedRetryException
 
CommandNeedRetryException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.CommandNeedRetryException
 
CommandNeedRetryException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.ql.CommandNeedRetryException
 
CommandProcessor - Interface in org.apache.hadoop.hive.ql.processors
 
CommandProcessorFactory - Class in org.apache.hadoop.hive.ql.processors
CommandProcessorFactory.
CommandProcessorResponse - Class in org.apache.hadoop.hive.ql.processors
Encapsulates the basic response info returned by classes the implement the CommandProcessor interfaace.
CommandProcessorResponse(int) - Constructor for class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
 
CommandProcessorResponse(int, String, String) - Constructor for class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
 
CommandProcessorResponse(int, String, String, Schema) - Constructor for class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
 
commitTxn() - Method in class org.apache.hadoop.hive.ql.lockmgr.DbTxnManager
 
commitTxn() - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveTxnManager
Commit the current transaction.
COMMON_JOIN - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
CommonFunctionInfo - Interface in org.apache.hadoop.hive.ql.exec
Interface for common functionality between FunctionInfo/WindowFunctionInfo
CommonJoinOperator<T extends JoinDesc> - Class in org.apache.hadoop.hive.ql.exec
Join operator implementation.
CommonJoinOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
CommonJoinOperator(CommonJoinOperator<T>) - Constructor for class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
CommonJoinResolver - Class in org.apache.hadoop.hive.ql.optimizer.physical
 
CommonJoinResolver() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.CommonJoinResolver
 
CommonJoinTaskDispatcher - Class in org.apache.hadoop.hive.ql.optimizer.physical
Iterator each tasks.
CommonJoinTaskDispatcher(PhysicalContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.CommonJoinTaskDispatcher
 
compact(String, String, String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Enqueue a compaction request.
CompactIndexHandler - Class in org.apache.hadoop.hive.ql.index.compact
 
CompactIndexHandler() - Constructor for class org.apache.hadoop.hive.ql.index.compact.CompactIndexHandler
 
CompactorMR - Class in org.apache.hadoop.hive.ql.txn.compactor
Class to do compactions via an MR job.
CompactorMR() - Constructor for class org.apache.hadoop.hive.ql.txn.compactor.CompactorMR
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable.Comparator
Compare the buffers in serialized form.
compare(Method, Method) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask.MethodComparator
 
compare(Object) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeGenericFuncEvaluator
If the genericUDF is a base comparison, it returns an integer based on the result of comparing the two sides of the UDF, like the compareTo method in Comparable.
compare(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringExpr
 
compare(Map.Entry<LineageInfo.DependencyKey, LineageInfo.Dependency>, Map.Entry<LineageInfo.DependencyKey, LineageInfo.Dependency>) - Method in class org.apache.hadoop.hive.ql.hooks.PostExecutePrinter.DependencyKeyComp
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hive.ql.io.HiveKey.Comparator
Compare the buffers in serialized form.
compare(Object[], ObjectInspector[], Object[], ObjectInspector[]) - Static method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank
 
compare(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
compare(Map.Entry<LongWritable, LongWritable>, Map.Entry<LongWritable, LongWritable>) - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.MyComparator
 
compareTo(Object) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
Compares two ByteWritables.
compareTo(AcidUtils.ParsedDelta) - Method in class org.apache.hadoop.hive.ql.io.AcidUtils.ParsedDelta
 
compareTo(BigDecimalWritable) - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
compareTo(Object) - Method in class org.apache.hadoop.hive.ql.io.RCFile.KeyBuffer
 
compareTo(RCFileKeyBufferWrapper) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
compareTo(RCFileValueBufferWrapper) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileValueBufferWrapper
 
compareTo(Object) - Method in class org.apache.hadoop.hive.ql.io.RCFile.ValueBuffer
 
compareTo(RecordIdentifier) - Method in class org.apache.hadoop.hive.ql.io.RecordIdentifier
 
compareTo(CheckResult.PartitionResult) - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult.PartitionResult
 
compareTo(WindowingSpec.BoundarySpec) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.CurrentRowSpec
 
compareTo(WindowingSpec.BoundarySpec) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.RangeBoundarySpec
 
compareTo(WindowingSpec.BoundarySpec) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.ValueBoundarySpec
 
compareTo(BoundaryDef) - Method in class org.apache.hadoop.hive.ql.plan.ptf.CurrentRowDef
 
compareTo(BoundaryDef) - Method in class org.apache.hadoop.hive.ql.plan.ptf.RangeBoundaryDef
 
compareTo(BoundaryDef) - Method in class org.apache.hadoop.hive.ql.plan.ptf.ValueBoundaryDef
 
compareTo(HiveRoleGrant) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
ComparisonOpMethodResolver - Class in org.apache.hadoop.hive.ql.exec
The class implements the method resolution for operators like (> < <= >= = <>).
ComparisonOpMethodResolver(Class<? extends UDF>) - Constructor for class org.apache.hadoop.hive.ql.exec.ComparisonOpMethodResolver
Constuctor.
compile(String) - Method in class org.apache.hadoop.hive.ql.Driver
Compile a new query.
compile(String, boolean) - Method in class org.apache.hadoop.hive.ql.Driver
Compile a new query, but potentially reset taskID counter.
COMPILE - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
compile(ParseContext, List<Task<? extends Serializable>>, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.TaskCompiler
 
compileAggregationBatchInfo(VectorAggregateExpression[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferBatch
 
compileAndRespond(String) - Method in class org.apache.hadoop.hive.ql.Driver
 
compileKeyWrapperBatch(VectorExpression[]) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapperBatch
Prepares a VectorHashKeyWrapperBatch to work for a specific set of keys.
CompileProcessor - Class in org.apache.hadoop.hive.ql.processors
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.
CompileProcessor() - Constructor for class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
componentize(PTFInvocationSpec) - Static method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
CompositeProcessor - Class in org.apache.hadoop.hive.ql.lib
CompositeProcessor.
CompositeProcessor(NodeProcessor...) - Constructor for class org.apache.hadoop.hive.ql.lib.CompositeProcessor
 
compress(CompressionKind) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
Sets the generic compression that is used to compress the data.
COMPRESSION - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcFile
Deprecated. 
COMPRESSION_BLOCK_SIZE - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcFile
Deprecated. 
CompressionKind - Enum in org.apache.hadoop.hive.ql.io.orc
An enumeration that lists the generic compression algorithms that can be applied to ORC files.
computCardinalityBasedCost(HiveRel) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCostUtil
 
computeCost(HiveTableScanRel) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCostUtil
 
computeKeys(Object, List<ExprNodeEvaluator>, List<ObjectInspector>) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
Return the key as a standard object.
computeMapJoinValues(Object, List<ExprNodeEvaluator>, List<ObjectInspector>, List<ExprNodeEvaluator>, List<ObjectInspector>, int[]) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
Return the value as a standard object.
computeSelfCost(RelOptPlanner) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveAggregateRel
 
computeSelfCost(RelOptPlanner) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveFilterRel
 
computeSelfCost(RelOptPlanner) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveJoinRel
 
computeSelfCost(RelOptPlanner) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveLimitRel
 
computeSelfCost(RelOptPlanner) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveProjectRel
 
computeSelfCost(RelOptPlanner) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveTableScanRel
 
computeValues(Object, List<ExprNodeEvaluator>, List<ObjectInspector>, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
Return the value as a standard object.
ConditionalResolver - Interface in org.apache.hadoop.hive.ql.plan
Conditional task resolution interface.
ConditionalResolverCommonJoin - Class in org.apache.hadoop.hive.ql.plan
ConditionalResolverSkewJoin.
ConditionalResolverCommonJoin() - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin
 
ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx - Class in org.apache.hadoop.hive.ql.plan
ConditionalResolverSkewJoinCtx.
ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx() - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
ConditionalResolverMergeFiles - Class in org.apache.hadoop.hive.ql.plan
Conditional task resolution interface.
ConditionalResolverMergeFiles() - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles
 
ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx - Class in org.apache.hadoop.hive.ql.plan
ConditionalResolverMergeFilesCtx.
ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx() - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx(List<Task<? extends Serializable>>, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
ConditionalResolverSkewJoin - Class in org.apache.hadoop.hive.ql.plan
ConditionalResolverSkewJoin.
ConditionalResolverSkewJoin() - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverSkewJoin
 
ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx - Class in org.apache.hadoop.hive.ql.plan
ConditionalResolverSkewJoinCtx.
ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx() - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx
For serialization use only.
ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx(HashMap<Path, Task<? extends Serializable>>, Task<? extends Serializable>) - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx
 
ConditionalTask - Class in org.apache.hadoop.hive.ql.exec
Conditional Task implementation.
ConditionalTask() - Constructor for class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
ConditionalWork - Class in org.apache.hadoop.hive.ql.plan
ConditionalWork.
ConditionalWork() - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalWork
 
ConditionalWork(List<? extends Serializable>) - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalWork
 
conf - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
conf - Variable in class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.exec.HiveTotalOrderPartitioner
 
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapper
 
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecReducer
 
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.io.avro.AvroContainerInputFormat
 
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.io.avro.AvroGenericRecordReader
 
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.io.NullRowsInputFormat
 
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileMergeMapper
 
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanMapper
 
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateMapper
 
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat
 
configure(MapredContext) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Additionally setup GenericUDAFEvaluator with MapredContext before initializing.
configure(MapredContext) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
Additionally setup GenericUDF with MapredContext before initializing.
configure(MapredContext) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTF
Additionally setup GenericUDTF with MapredContext before initializing.
configure(MapredContext) - Method in class org.apache.hadoop.hive.ql.udf.generic.UDFCurrentDB
 
configureInputJobProperties(TableDesc, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
configureInputJobProperties(TableDesc, Map<String, String>) - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
This method is called to allow the StorageHandlers the chance to populate the JobContext.getConfiguration() with properties that maybe be needed by the handler's bundled artifacts (ie InputFormat, SerDe, etc).
configureInputJobPropertiesForStorageHandler(TableDesc) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Loads the storage handler (if one exists) for the given table and invokes HiveStorageHandler.configureInputJobProperties(TableDesc, java.util.Map).
configureJobConf(TableDesc, JobConf) - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
configureJobConf(TableDesc, JobConf) - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
Called just before submitting MapReduce job.
configureJobConf(JobConf) - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
configureJobConf(JobConf) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
configureJobConf(JobConf) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
configureJobConf(TableDesc, JobConf) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
configureJobConf(JobConf) - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
configureJobConf(JobConf) - Method in class org.apache.hadoop.hive.ql.plan.UnionWork
 
configureJobConfAndExtractJars(JobConf) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
Calls configureJobConf on instances of work that are part of this TezWork.
configureOutputJobProperties(TableDesc, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
configureOutputJobProperties(TableDesc, Map<String, String>) - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
This method is called to allow the StorageHandlers the chance to populate the JobContext.getConfiguration() with properties that maybe be needed by the handler's bundled artifacts (ie InputFormat, SerDe, etc).
configureOutputJobPropertiesForStorageHandler(TableDesc) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Loads the storage handler (if one exists) for the given table and invokes HiveStorageHandler.configureOutputJobProperties(TableDesc, java.util.Map).
configureTableJobProperties(TableDesc, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
configureTableJobProperties(TableDesc, Map<String, String>) - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
Deprecated. 
conflictingArchiveNameOrNull(Hive, Table, LinkedHashMap<String, String>) - Static method in class org.apache.hadoop.hive.ql.exec.ArchiveUtils
Determines if one can insert into partition(s), or there's a conflict with archive.
connect(BaseWork, BaseWork, TezEdgeProperty) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
connect adds an edge between a and b.
connect(Configuration, Task) - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsAggregator
 
connect(Configuration, Task) - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsAggregatorTez
 
connect(Configuration) - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsPublisher
 
connect(Configuration, Task) - Method in class org.apache.hadoop.hive.ql.stats.fs.FSStatsAggregator
 
connect(Configuration) - Method in class org.apache.hadoop.hive.ql.stats.fs.FSStatsPublisher
 
connect(Configuration, Task) - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsAggregator
 
connect(Configuration) - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsPublisher
 
connect(Configuration, Task) - Method in interface org.apache.hadoop.hive.ql.stats.StatsAggregator
This method connects to the temporary storage.
connect(Configuration) - Method in interface org.apache.hadoop.hive.ql.stats.StatsPublisher
This method connects to the intermediate statistics database.
connectedReduceSinks - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
connectLeadLagFunctionsToPartition(PTFDesc, PTFPartition.PTFPartitionIterator<Object>) - Static method in class org.apache.hadoop.hive.ql.exec.PTFOperator
 
connectWithRetry(String, int, int) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Retry connecting to a database with random backoff (same as the one implemented in HDFS-767).
console - Static variable in class org.apache.hadoop.hive.ql.processors.AddResourceProcessor
 
console - Static variable in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
console - Static variable in class org.apache.hadoop.hive.ql.processors.DeleteResourceProcessor
 
console - Static variable in class org.apache.hadoop.hive.ql.processors.DfsProcessor
 
ConstantVectorExpression - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Constant is represented as a vector with repeating values.
ConstantVectorExpression() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
ConstantVectorExpression(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
ConstantVectorExpression(int, double) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
ConstantVectorExpression(int, byte[]) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
ConstantVectorExpression(int, Decimal128) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
constructJoinLeafPredicateInfo(HiveJoinRel, RexNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinLeafPredicateInfo
 
constructJoinPredicateInfo(HiveJoinRel) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinPredicateInfo
 
constructJoinPredicateInfo(HiveJoinRel, RexNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinPredicateInfo
 
contains(FileSplit) - Method in class org.apache.hadoop.hive.ql.index.HiveIndexResult
 
containsPredicate(ExprNodeDesc, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
return true if predicate is already included in source
contentsEqual(InputStream, InputStream, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
ContentSummaryInputFormat - Interface in org.apache.hadoop.hive.ql.io
ContentSummayInputFormat provides an interface to let the input format itself figure the content summary for a give input path.
Context - Class in org.apache.hadoop.hive.ql
Context for Semantic Analyzers.
Context(Configuration) - Constructor for class org.apache.hadoop.hive.ql.Context
 
Context(Configuration, String) - Constructor for class org.apache.hadoop.hive.ql.Context
Create a Context with a given executionId.
CONVENTION - Static variable in interface org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveRel
Calling convention for relational operations that occur in Hive.
convert(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.DefaultFetchFormatter
 
convert(Object, ObjectInspector) - Method in interface org.apache.hadoop.hive.ql.exec.FetchFormatter
 
convert(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.FetchFormatter.ThriftFormatter
 
convert(List<String>, List<TypeInfo>) - Static method in class org.apache.hadoop.hive.ql.io.parquet.convert.HiveSchemaConverter
 
convert(RelNode, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.translator.ASTConverter
 
convert(SortRel) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.translator.ASTConverter
 
convert(Operator<? extends OperatorDesc>, RelOptCluster, RelOptSchema, SemanticAnalyzer, ParseContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.translator.RelNodeConverter
 
convert(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.translator.RexNodeConverter
 
convert(TypeInfo, RelDataTypeFactory) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.translator.TypeConverter
 
convert(PrimitiveTypeInfo, RelDataTypeFactory) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.translator.TypeConverter
 
convert(ListTypeInfo, RelDataTypeFactory) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.translator.TypeConverter
 
convert(MapTypeInfo, RelDataTypeFactory) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.translator.TypeConverter
 
convert(StructTypeInfo, RelDataTypeFactory) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.translator.TypeConverter
 
convert(UnionTypeInfo, RelDataTypeFactory) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.translator.TypeConverter
 
CONVERTED_MAPJOIN - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
CONVERTED_MAPJOIN_LOCAL - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
CONVERTED_SORTMERGEJOIN - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
convertExprToFilter(byte[]) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionExpressionForMetastore
 
convertIfNecessary(Object...) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ConversionHelper
 
convertIfNecessary(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ReturnObjectInspectorResolver
Convert the return Object if necessary (when the ObjectInspectors of different possibilities are not all the same).
ConvertJoinMapJoin - Class in org.apache.hadoop.hive.ql.optimizer
ConvertJoinMapJoin is an optimization that replaces a common join (aka shuffle join) with a map join (aka broadcast or fragment replicate join when possible.
ConvertJoinMapJoin() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ConvertJoinMapJoin
 
convertJoinMapJoin(JoinOperator, OptimizeTezProcContext, int) - Method in class org.apache.hadoop.hive.ql.optimizer.ConvertJoinMapJoin
 
convertJoinOpMapJoinOp(HiveConf, LinkedHashMap<Operator<? extends OperatorDesc>, OpParseContext>, JoinOperator, QBJoinTree, int, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
convertMapJoin(HiveConf, LinkedHashMap<Operator<? extends OperatorDesc>, OpParseContext>, JoinOperator, QBJoinTree, int, boolean, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
convert a regular join to a a map-side join.
convertOpTree(RelNode, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.translator.DerivedTableInjector
 
convertRowBatchBlobToVectorizedBatch(Object, int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatchCtx
Deserialized set of rows and populates the batch
convertSMBJoinToMapJoin(HiveConf, Map<Operator<? extends OperatorDesc>, OpParseContext>, SMBMapJoinOperator, QBJoinTree, int, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
convert a sortmerge join to a a map-side join.
convertToArray(Map<Byte, T>, Class<T>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
convertUTF8WithBuf(byte[], char[], int, int) - Static method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
 
convertWindowsScriptToUnix(File) - Static method in class org.apache.hadoop.hive.ql.util.DosToUnix
 
copy() - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
copy() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
copy() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinRowContainer
 
copy() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
copy(RelTraitSet, RelNode, BitSet, List<AggregateCall>) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveAggregateRel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveFilterRel
 
copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveJoinRel
 
copy(RelTraitSet, RexNode, RelNode, RelNode, HiveJoinRel.JoinAlgorithm, HiveJoinRel.MapJoinStreamingRelation) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveJoinRel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveLimitRel
 
copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveProjectRel
 
copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveSortRel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveTableScanRel
 
copyKey() - Method in class org.apache.hadoop.hive.ql.exec.KeyWrapper
 
copyKey(KeyWrapper) - Method in class org.apache.hadoop.hive.ql.exec.KeyWrapper
 
copyKey() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
copyKey(KeyWrapper) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
copyPartSpecMappingOnly() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
copySelected(boolean, int[], int, BytesColumnVector) - Method in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
Copy the current object contents into the output.
copySelected(boolean, int[], int, DoubleColumnVector) - Method in class org.apache.hadoop.hive.ql.exec.vector.DoubleColumnVector
 
copySelected(BytesColumnVector, boolean, int[], int, LongColumnVector) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColCol
 
copySelected(boolean, int[], int, LongColumnVector) - Method in class org.apache.hadoop.hive.ql.exec.vector.LongColumnVector
 
copySelected(boolean, int[], int, DoubleColumnVector) - Method in class org.apache.hadoop.hive.ql.exec.vector.LongColumnVector
 
copyTableJobPropertiesToConf(TableDesc, JobConf) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Copies the storage handler properties configured for a table descriptor to a runtime job configuration.
CopyTask - Class in org.apache.hadoop.hive.ql.exec
CopyTask implementation.
CopyTask() - Constructor for class org.apache.hadoop.hive.ql.exec.CopyTask
 
copyToDFSDirecory(FileSystem, Path) - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
copyToNewInstance(Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
Some information may be set during initialize() which needs to be saved when the UDF is copied.
copyToNewInstance(Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
copyToStandardObject(Object[], ObjectInspector[], ObjectInspectorUtils.ObjectInspectorCopyOption) - Static method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank
 
CopyWork - Class in org.apache.hadoop.hive.ql.plan
CopyWork.
CopyWork() - Constructor for class org.apache.hadoop.hive.ql.plan.CopyWork
 
CopyWork(Path, Path) - Constructor for class org.apache.hadoop.hive.ql.plan.CopyWork
 
CopyWork(Path, Path, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.CopyWork
 
CorrelationOptimizer - Class in org.apache.hadoop.hive.ql.optimizer.correlation
Implementation of Correlation Optimizer.
CorrelationOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationOptimizer
 
CorrelationUtilities - Class in org.apache.hadoop.hive.ql.optimizer.correlation
Utilities for both CorrelationOptimizer and ReduceSinkDeDuplication.
CorrelationUtilities() - Constructor for class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
cost(Stack<Node>) - Method in interface org.apache.hadoop.hive.ql.lib.Rule
 
cost(Stack<Node>) - Method in class org.apache.hadoop.hive.ql.lib.RuleExactMatch
This function returns the cost of the rule for the specified stack.
cost(Stack<Node>) - Method in class org.apache.hadoop.hive.ql.lib.RuleRegExp
This function returns the cost of the rule for the specified stack.
CostBasedOptimizer - Class in org.apache.hadoop.hive.ql.optimizer
 
CostBasedOptimizer(Operator, SemanticAnalyzer, ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.CostBasedOptimizer
 
count() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
Return count of qualifying rows.
count - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator.BinaryStatsAgg
 
count - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg
 
CounterStatsAggregator - Class in org.apache.hadoop.hive.ql.stats
 
CounterStatsAggregator() - Constructor for class org.apache.hadoop.hive.ql.stats.CounterStatsAggregator
 
CounterStatsAggregatorTez - Class in org.apache.hadoop.hive.ql.stats
This class aggregates stats via counters and does so for Tez Tasks.
CounterStatsAggregatorTez() - Constructor for class org.apache.hadoop.hive.ql.stats.CounterStatsAggregatorTez
 
CounterStatsPublisher - Class in org.apache.hadoop.hive.ql.stats
 
CounterStatsPublisher() - Constructor for class org.apache.hadoop.hive.ql.stats.CounterStatsPublisher
 
countFalses - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator.BooleanStatsAgg
 
countNulls - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator.BinaryStatsAgg
 
countNulls - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator.BooleanStatsAgg
 
countNulls - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator.DecimalStatsAgg
 
countNulls - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.DoubleStatsAgg
 
countNulls - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.LongStatsAgg
 
countNulls - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg
 
countSel() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
countSelDi() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
countTrues - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator.BooleanStatsAgg
 
create(Table, Map<String, String>) - Static method in class org.apache.hadoop.hive.ql.exec.ArchiveUtils.PartSpecInfo
Extract partial prefix specification from table and key-value map
create(HiveConf, SerDe, StructObjectInspector, StructObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
create() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
create() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
create(int) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveArrayInspector
 
create(byte) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetByteInspector
 
create(short) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetShortInspector
 
create(Text) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetStringInspector
 
create(String) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetStringInspector
 
create(RCFile.KeyBuffer) - Static method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
create(ExprNodeGenericFuncDesc) - Method in class org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Factory
 
create(String) - Method in class org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Factory
 
create() - Static method in class org.apache.hadoop.hive.ql.metadata.formatting.MapBuilder
 
create(RelNode, List<RexNode>, List<String>) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveProjectRel
Creates a HiveProjectRel with no sort keys.
create(RelOptCluster, RelNode, List<RexNode>, RelDataType, List<RelCollation>) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveProjectRel
Creates a HiveProjectRel.
CREATE - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
create(HiveConf) - Static method in class org.apache.hadoop.hive.ql.session.CreateTableAutomaticGrant
 
createBucketFile(Path, int) - Static method in class org.apache.hadoop.hive.ql.io.AcidUtils
Create the bucket filename.
createCompressedStream(JobConf, OutputStream) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Convert an output stream to a compressed output stream based on codecs and compression options specified in the Job Configuration.
createCompressedStream(JobConf, OutputStream, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Convert an output stream to a compressed output stream based on codecs codecs in the Job Configuration.
createCondTask(HiveConf, Task<? extends Serializable>, MoveWork, Serializable, String) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Construct a conditional task given the current leaf task, the MoveWork and the MapredWork.
createConfiguration(HiveConf) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
Creates and initializes a JobConf object that can be used to execute the DAG.
createCreateRoleTask(ASTNode, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in interface org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactory
 
createCreateRoleTask(ASTNode, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactoryImpl
 
createDatabase(Database, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Create a database
createDatabase(Database) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Create a Database.
CreateDatabaseDesc - Class in org.apache.hadoop.hive.ql.plan
CreateDatabaseDesc.
CreateDatabaseDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
For serialization only.
CreateDatabaseDesc(String, String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
CreateDatabaseDesc(String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
createDirsWithPermission(Configuration, Path, FsPermission) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
createDirsWithPermission(Configuration, Path, FsPermission, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
createDropRoleTask(ASTNode, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in interface org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactory
 
createDropRoleTask(ASTNode, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactoryImpl
 
createEdge(VertexGroup, JobConf, Vertex, TezEdgeProperty) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
Given a Vertex group and a vertex createEdge will create an Edge between them.
createEdge(JobConf, Vertex, JobConf, Vertex, TezEdgeProperty) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
Given two vertices and their respective configuration objects createEdge will create an Edge object that connects the two.
createExportDump(FileSystem, Path, Table, List<Partition>) - Static method in class org.apache.hadoop.hive.ql.parse.EximUtil
 
createFileId(String) - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
createFilename(Path, AcidOutputFormat.Options) - Static method in class org.apache.hadoop.hive.ql.io.AcidUtils
Create a filename for a bucket file.
createFileName(String, String) - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
createFirstPartitionForChain(ObjectInspector, HiveConf, boolean) - Method in class org.apache.hadoop.hive.ql.exec.PTFOperator
Create a new Partition.
createFunction(Function) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
CreateFunctionDesc - Class in org.apache.hadoop.hive.ql.plan
CreateFunctionDesc.
CreateFunctionDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
For serialization only.
CreateFunctionDesc(String, boolean, String, List<ResourceUri>) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
createGrantRoleTask(ASTNode, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in interface org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactory
 
createGrantRoleTask(ASTNode, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactoryImpl
 
createGrantTask(ASTNode, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in interface org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactory
 
createGrantTask(ASTNode, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactoryImpl
 
createHiveAuthorizer(HiveMetastoreClientFactory, HiveConf, HiveAuthenticationProvider) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerFactory
Create a new instance of HiveAuthorizer, initialized with the given objects.
createHiveAuthorizer(HiveMetastoreClientFactory, HiveConf, HiveAuthenticationProvider) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAuthorizerFactory
 
createIndex(String, String, String, List<String>, String, boolean, String, String, String, String, String, Map<String, String>, Map<String, String>, Map<String, String>, String, String, String, String, String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
CreateIndexDesc - Class in org.apache.hadoop.hive.ql.plan
create index descriptor
CreateIndexDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
CreateIndexDesc(String, String, List<String>, String, boolean, String, String, String, String, String, Map<String, String>, Map<String, String>, String, Map<String, String>, String, String, String, String, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
createInstance(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.tez.TezCacheAccess
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.avro.AvroGenericRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.NullRowsInputFormat.NullRowsRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRawRecordMerger
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.parquet.read.ParquetRecordReaderWrapper
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
CreateMacroDesc - Class in org.apache.hadoop.hive.ql.plan
CreateMacroDesc.
CreateMacroDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CreateMacroDesc
For serialization only.
CreateMacroDesc(String, List<String>, List<TypeInfo>, ExprNodeDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateMacroDesc
 
createMapWork(GenTezProcContext, Operator<?>, TezWork, PrunedPartitionList) - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
createMetadata(Text...) - Static method in class org.apache.hadoop.hive.ql.io.RCFile
Create a metadata object with alternating key-value pairs.
createMetaPartitionObject(Table, Map<String, String>, Path) - Static method in class org.apache.hadoop.hive.ql.metadata.Partition
 
createMoveTask(Task<? extends Serializable>, boolean, FileSinkOperator, ParseContext, List<Task<MoveWork>>, HiveConf, DependencyCollectionTask) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Create and add any dependent move tasks
createMRWorkForMergingFiles(FileSinkOperator, Path, DependencyCollectionTask, List<Task<MoveWork>>, HiveConf, Task<? extends Serializable>) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
createObjectInspector(TypeInfo) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcStruct
 
createPartition(Table, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Creates a partition.
createPartitions(AddPartitionDesc) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
createPath(Table) - Method in class org.apache.hadoop.hive.ql.exec.ArchiveUtils.PartSpecInfo
Creates path where partitions matching prefix should lie in filesystem
createPlanner() - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveVolcanoPlanner
 
createPreWarmContext(TezSessionConfiguration, int, Map<String, LocalResource>) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
createRCFileMergeTask(FileSinkDesc, Path, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Create a block level merge task for RCFiles.
createRCFileWriter(JobConf, FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Create a RCFile output stream based on job configuration Uses user supplied compression flag (rather than obtaining it from the Job Configuration).
createReader(FileSystem, Path) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcFile
Create an ORC file reader.
createReader(Path, OrcFile.ReaderOptions) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcFile
 
createReaderFromFile(Reader, Configuration, long, long) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcNewInputFormat
 
createReduceWork(GenTezProcContext, Operator<?>, TezWork) - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
createRevokeRoleTask(ASTNode, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in interface org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactory
 
createRevokeRoleTask(ASTNode, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactoryImpl
 
createRevokeTask(ASTNode, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in interface org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactory
 
createRevokeTask(ASTNode, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactoryImpl
 
createRole(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
createRole(String, HivePrincipal) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessController
 
createRole(String, HivePrincipal) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
Create role
createRole(String, HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
createRole(String, HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
createRootTask(HiveConf, Set<ReadEntity>, Set<WriteEntity>, StringBuilder, LinkedHashMap<String, String>, String, String) - Static method in class org.apache.hadoop.hive.ql.optimizer.IndexUtils
 
createRow() - Method in class org.apache.hadoop.hive.ql.exec.BinaryRecordReader
 
createRow() - Method in interface org.apache.hadoop.hive.ql.exec.RecordReader
 
createRow() - Method in class org.apache.hadoop.hive.ql.exec.TextRecordReader
 
createSampler(FetchWork, HiveConf, JobConf, Operator<?>) - Static method in class org.apache.hadoop.hive.ql.exec.PartitionKeySampler
 
createSequenceWriter(JobConf, FileSystem, Path, Class<?>, Class<?>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Create a sequencefile output stream based on job configuration.
createSequenceWriter(JobConf, FileSystem, Path, Class<?>, Class<?>, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Create a sequencefile output stream based on job configuration Uses user supplied compression flag (rather than obtaining it from the Job Configuration).
createSetRoleTask(String, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in interface org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactory
 
createSetRoleTask(String, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactoryImpl
 
createShowCurrentRoleTask(HashSet<ReadEntity>, HashSet<WriteEntity>, Path) - Method in interface org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactory
 
createShowCurrentRoleTask(HashSet<ReadEntity>, HashSet<WriteEntity>, Path) - Method in class org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactoryImpl
 
createShowGrantTask(ASTNode, Path, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in interface org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactory
 
createShowGrantTask(ASTNode, Path, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactoryImpl
 
createShowRoleGrantTask(ASTNode, Path, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in interface org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactory
 
createShowRoleGrantTask(ASTNode, Path, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactoryImpl
 
createShowRolePrincipalsTask(ASTNode, Path, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in interface org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactory
 
createShowRolePrincipalsTask(ASTNode, Path, HashSet<ReadEntity>, HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactoryImpl
 
createSpec(Partition) - Method in class org.apache.hadoop.hive.ql.metadata.Table
Creates a partition name -> value spec map object
createTable(String, List<String>, List<String>, Class<? extends InputFormat>, Class<?>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Creates a table metdata and the directory for the table data
createTable(String, List<String>, List<String>, Class<? extends InputFormat>, Class<?>, int, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Creates a table metdata and the directory for the table data
createTable(Table) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Creates the table with the give objects
createTable(Table, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Creates the table with the give objects
CreateTableAutomaticGrant - Class in org.apache.hadoop.hive.ql.session
 
CreateTableAutomaticGrant() - Constructor for class org.apache.hadoop.hive.ql.session.CreateTableAutomaticGrant
 
createTableDesc(StructObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer
 
CreateTableDesc - Class in org.apache.hadoop.hive.ql.plan
CreateTableDesc.
CreateTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
CreateTableDesc(String, String, boolean, List<FieldSchema>, List<FieldSchema>, List<String>, List<Order>, int, String, String, String, String, String, String, String, String, String, String, String, Map<String, String>, Map<String, String>, boolean, List<String>, List<List<String>>) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
CreateTableDesc(String, boolean, List<FieldSchema>, List<FieldSchema>, List<String>, List<Order>, int, String, String, String, String, String, String, String, String, String, String, String, Map<String, String>, Map<String, String>, boolean, List<String>, List<List<String>>) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
CreateTableLikeDesc - Class in org.apache.hadoop.hive.ql.plan
CreateTableLikeDesc.
CreateTableLikeDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
CreateTableLikeDesc(String, boolean, String, String, String, String, Map<String, String>, Map<String, String>, boolean, String) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
createTempDir(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Create a temp dir in specified baseDir This can go away once hive moves to support only JDK 7 and can use Files.createTempDirectory Guava Files.createTempDir() does not take a base dir
createTemporaryTableScanOperator(RowSchema) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
createTezDir(Path, Configuration) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
createTezDir creates a temporary directory in the scratchDir folder to be used with Tez.
createTmpDirs(Configuration, MapWork) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Hive uses tmp directories to capture the output of each FileSinkOperator.
createTmpDirs(Configuration, ReduceWork) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Hive uses tmp directories to capture the output of each FileSinkOperator.
createUnionWork(GenTezProcContext, Operator<?>, TezWork) - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.avro.AvroGenericRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.NullRowsInputFormat.NullRowsRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRawRecordMerger
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.parquet.read.ParquetRecordReaderWrapper
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
createVectorizedRowBatch() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatchCtx
Creates a Vectorized row batch and the column vectors.
createVertex(JobConf, BaseWork, Path, LocalResource, List<LocalResource>, FileSystem, Context, boolean, TezWork) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
Create a vertex from a given work object.
CreateViewDesc - Class in org.apache.hadoop.hive.ql.plan
CreateViewDesc.
CreateViewDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CreateViewDesc
For serialization only.
CreateViewDesc(String, List<FieldSchema>, String, Map<String, String>, List<String>, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
createWriter(Path, OrcFile.WriterOptions) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcFile
Create an ORC file writer.
createWriter(FileSystem, Path, Configuration, ObjectInspector, long, CompressionKind, int, int) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcFile
Create an ORC file writer.
CrossProductCheck - Class in org.apache.hadoop.hive.ql.optimizer.physical
 
CrossProductCheck() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.CrossProductCheck
 
ctrlaCode - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
CuckooSetBytes - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
A high-performance set implementation used to support fast set membership testing, using Cuckoo hashing.
CuckooSetBytes(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CuckooSetBytes
Allocate a new set to hold expectedSize values.
CuckooSetDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
A high-performance set implementation used to support fast set membership testing, using Cuckoo hashing.
CuckooSetDouble(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CuckooSetDouble
 
CuckooSetLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
A high-performance set implementation used to support fast set membership testing, using Cuckoo hashing.
CuckooSetLong(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.CuckooSetLong
Allocate a new set to hold expectedSize values.
currBigKeyTag - Variable in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
CURRENT - Static variable in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.Version
 
currentMapJoinOperators - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
currentRootOperator - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
CurrentRowDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
CurrentRowDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.CurrentRowDef
 
currentTask - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
currentUnionOperators - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
CustomPartitionEdge - Class in org.apache.hadoop.hive.ql.exec.tez
 
CustomPartitionEdge() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionEdge
 
CustomPartitionVertex - Class in org.apache.hadoop.hive.ql.exec.tez
 
CustomPartitionVertex() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionVertex
 

D

DagUtils - Class in org.apache.hadoop.hive.ql.exec.tez
DagUtils.
databaseExists(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Query metadata to see if a database with the given name already exists.
DataCorruptErrorHeuristic - Class in org.apache.hadoop.hive.ql.exec.errors
Detects the condition where there is a error with one of the input files in the query.
DataCorruptErrorHeuristic() - Constructor for class org.apache.hadoop.hive.ql.exec.errors.DataCorruptErrorHeuristic
 
DataWritableGroupConverter - Class in org.apache.hadoop.hive.ql.io.parquet.convert
A MapWritableGroupConverter, real converter between hive and parquet types recursively for complex types.
DataWritableGroupConverter(GroupType, GroupType) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.convert.DataWritableGroupConverter
 
DataWritableGroupConverter(GroupType, HiveGroupConverter, int) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.convert.DataWritableGroupConverter
 
DataWritableGroupConverter(GroupType, HiveGroupConverter, int, GroupType) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.convert.DataWritableGroupConverter
 
DataWritableReadSupport - Class in org.apache.hadoop.hive.ql.io.parquet.read
A MapWritableReadSupport Manages the translation between Hive and Parquet
DataWritableReadSupport() - Constructor for class org.apache.hadoop.hive.ql.io.parquet.read.DataWritableReadSupport
 
DataWritableRecordConverter - Class in org.apache.hadoop.hive.ql.io.parquet.convert
A MapWritableReadSupport, encapsulates the tuples
DataWritableRecordConverter(GroupType, GroupType) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.convert.DataWritableRecordConverter
 
DataWritableWriter - Class in org.apache.hadoop.hive.ql.io.parquet.write
DataWritableWriter is a writer, that will read an ArrayWritable and give the data to parquet with the expected schema
DataWritableWriter(RecordConsumer, GroupType) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.write.DataWritableWriter
 
DataWritableWriteSupport - Class in org.apache.hadoop.hive.ql.io.parquet.write
DataWritableWriteSupport is a WriteSupport for the DataWritableWriter
DataWritableWriteSupport() - Constructor for class org.apache.hadoop.hive.ql.io.parquet.write.DataWritableWriteSupport
 
DateColumnStatistics - Interface in org.apache.hadoop.hive.ql.io.orc
Statistics for DATE columns.
DbLockManager - Class in org.apache.hadoop.hive.ql.lockmgr
An implementation of HiveLockManager for use with DbTxnManager.
DbTxnManager - Class in org.apache.hadoop.hive.ql.lockmgr
An implementation of HiveTxnManager that stores the transactions in the metastore database.
DDLDesc - Class in org.apache.hadoop.hive.ql.plan
DDLDesc.
DDLDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DDLDesc
 
DDLSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
DDLSemanticAnalyzer.
DDLSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.DDLSemanticAnalyzer
 
DDLSemanticAnalyzer(HiveConf, Hive) - Constructor for class org.apache.hadoop.hive.ql.parse.DDLSemanticAnalyzer
 
DDLTask - Class in org.apache.hadoop.hive.ql.exec
DDLTask implementation.
DDLTask() - Constructor for class org.apache.hadoop.hive.ql.exec.DDLTask
 
DDLWork - Class in org.apache.hadoop.hive.ql.plan
DDLWork.
DDLWork() - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, CreateIndexDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(AlterIndexDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, CreateDatabaseDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, DescDatabaseDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, AlterDatabaseDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, TruncateTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, DropDatabaseDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, SwitchDatabaseDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, AlterTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, AlterIndexDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, CreateTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, CreateTableLikeDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, CreateViewDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, DropTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, DescTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowDatabasesDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowTablesDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowColumnsDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, LockTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, UnlockTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, LockDatabaseDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, UnlockDatabaseDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowFunctionsDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowLocksDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowCompactionsDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowTxnsDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, DescFunctionDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowPartitionsDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowCreateTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, AddPartitionDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, RenamePartitionDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, AlterTableSimpleDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, MsckDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowTableStatusDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowTblPropertiesDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, DropIndexDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, RoleDDLDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, GrantDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowGrantDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, RevokeDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, GrantRevokeRoleDDL) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowIndexesDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, AlterTablePartMergeFilesDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, AlterTableAlterPartDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, AlterTableExchangePartition) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DECIMAL_ONE - Static variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
DecimalColumnInList - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Output a boolean value indicating if a column is IN a list of constants.
DecimalColumnInList() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalColumnInList
 
DecimalColumnInList(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalColumnInList
After construction you must call setInListValues() to add the values to the IN set.
DecimalColumnStatistics - Interface in org.apache.hadoop.hive.ql.io.orc
Statistics for decimal columns.
DecimalColumnVector - Class in org.apache.hadoop.hive.ql.exec.vector
 
DecimalColumnVector(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.DecimalColumnVector
 
DecimalColumnVector(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.DecimalColumnVector
 
DecimalNumDistinctValueEstimator - Class in org.apache.hadoop.hive.ql.udf.generic
 
DecimalNumDistinctValueEstimator(int) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.DecimalNumDistinctValueEstimator
 
DecimalNumDistinctValueEstimator(String, int) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.DecimalNumDistinctValueEstimator
 
DecimalToStringUnaryUDF - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This is a superclass for unary decimal functions returning strings that operate directly on the input and set the output.
DecimalToStringUnaryUDF(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalToStringUnaryUDF
 
DecimalToStringUnaryUDF() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalToStringUnaryUDF
 
decimalTypePattern - Static variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
DecimalUtil - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Utility functions for vector operations on decimal values.
DecimalUtil() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
decomposePredicate(JobConf, Deserializer, ExprNodeDesc) - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStoragePredicateHandler
Gives the storage handler a chance to decompose a predicate.
DeepParquetHiveMapInspector - Class in org.apache.hadoop.hive.ql.io.parquet.serde
The DeepParquetHiveMapInspector will inspect an ArrayWritable, considering it as a Hive map.
It can also inspect a Map if Hive decides to inspect the result of an inspection.
When trying to access elements from the map it will iterate over all keys, inspecting them and comparing them to the desired key.
DeepParquetHiveMapInspector(ObjectInspector, ObjectInspector) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.serde.DeepParquetHiveMapInspector
 
DEFAULT_PROJECT_FACTORY - Static variable in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveProjectRel
 
DEFAULT_SIZE - Static variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
DefaultBucketMatcher - Class in org.apache.hadoop.hive.ql.exec
 
DefaultBucketMatcher() - Constructor for class org.apache.hadoop.hive.ql.exec.DefaultBucketMatcher
 
DefaultFetchFormatter<T> - Class in org.apache.hadoop.hive.ql.exec
serialize row by user specified serde and call toString() to make string type result
DefaultFetchFormatter() - Constructor for class org.apache.hadoop.hive.ql.exec.DefaultFetchFormatter
 
DefaultGraphWalker - Class in org.apache.hadoop.hive.ql.lib
base class for operator graph walker this class takes list of starting ops and walks them one by one.
DefaultGraphWalker(Dispatcher) - Constructor for class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
Constructor.
DefaultHiveAuthorizationProvider - Class in org.apache.hadoop.hive.ql.security.authorization
 
DefaultHiveAuthorizationProvider() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.DefaultHiveAuthorizationProvider
 
DefaultHiveMetastoreAuthorizationProvider - Class in org.apache.hadoop.hive.ql.security.authorization
 
DefaultHiveMetastoreAuthorizationProvider() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.DefaultHiveMetastoreAuthorizationProvider
 
DefaultHivePartitioner<K2,V2> - Class in org.apache.hadoop.hive.ql.io
Partition keys by their Object.hashCode().
DefaultHivePartitioner() - Constructor for class org.apache.hadoop.hive.ql.io.DefaultHivePartitioner
 
DefaultRuleDispatcher - Class in org.apache.hadoop.hive.ql.lib
Dispatches calls to relevant method in processor.
DefaultRuleDispatcher(NodeProcessor, Map<Rule, NodeProcessor>, NodeProcessorCtx) - Constructor for class org.apache.hadoop.hive.ql.lib.DefaultRuleDispatcher
Constructor.
DefaultStorageHandler - Class in org.apache.hadoop.hive.ql.metadata
DefaultStorageHandler is an implementation of HiveStorageHandler which supplies the standard defaults for all options.
DefaultStorageHandler() - Constructor for class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
defaultTd - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
DefaultUDAFEvaluatorResolver - Class in org.apache.hadoop.hive.ql.exec
The default UDAF Method resolver.
DefaultUDAFEvaluatorResolver(Class<? extends UDAF>) - Constructor for class org.apache.hadoop.hive.ql.exec.DefaultUDAFEvaluatorResolver
Constructor.
DefaultUDFMethodResolver - Class in org.apache.hadoop.hive.ql.exec
The default UDF Method resolver.
DefaultUDFMethodResolver(Class<? extends UDF>) - Constructor for class org.apache.hadoop.hive.ql.exec.DefaultUDFMethodResolver
Constructor.
delete(long, long, long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater
 
delete(long, long, long) - Method in interface org.apache.hadoop.hive.ql.io.RecordUpdater
Delete a row from the table.
DELETE - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
delete_resource(SessionState.ResourceType, String) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
delete_resource(SessionState.ResourceType) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
deletePartitionColumnStatistics(String, String, String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
DeleteResourceProcessor - Class in org.apache.hadoop.hive.ql.processors
DeleteResourceProcessor.
DeleteResourceProcessor() - Constructor for class org.apache.hadoop.hive.ql.processors.DeleteResourceProcessor
 
deleteTableColumnStatistics(String, String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
DELTA_DIGITS - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
DELTA_PREFIX - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
DemuxDesc - Class in org.apache.hadoop.hive.ql.plan
Demux operator descriptor implementation.
DemuxDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DemuxDesc
 
DemuxDesc(Map<Integer, Integer>, Map<Integer, Integer>, Map<Integer, Integer>, List<TableDesc>, List<TableDesc>) - Constructor for class org.apache.hadoop.hive.ql.plan.DemuxDesc
 
DemuxOperator - Class in org.apache.hadoop.hive.ql.exec
DemuxOperator is an operator used by MapReduce Jobs optimized by CorrelationOptimizer.
DemuxOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
DependencyCollectionTask - Class in org.apache.hadoop.hive.ql.exec
DependencyCollectionTask.
DependencyCollectionTask() - Constructor for class org.apache.hadoop.hive.ql.exec.DependencyCollectionTask
 
DependencyCollectionWork - Class in org.apache.hadoop.hive.ql.plan
DependencyCollectionWork
DependencyCollectionWork() - Constructor for class org.apache.hadoop.hive.ql.plan.DependencyCollectionWork
 
dependencyTask - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
deriveBaseFileName(String) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
Attempt to derive a virtual base file name property from the path.
deriveBucketMapJoinMapping() - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
DerivedTableInjector - Class in org.apache.hadoop.hive.ql.optimizer.optiq.translator
 
DerivedTableInjector() - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.translator.DerivedTableInjector
 
deriveExplainAttributes() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
deriveExplainAttributes() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
Derive additional attributes to be rendered by EXPLAIN.
deriveSumFieldTypeInfo(int, int) - Static method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage
The intermediate sum field has 10 more integer digits with the same scale.
descClass - Variable in class org.apache.hadoop.hive.ql.exec.OperatorFactory.OpTuple
 
DescDatabaseDesc - Class in org.apache.hadoop.hive.ql.plan
DescDatabaseDesc.
DescDatabaseDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
DescDatabaseDesc(Path, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
DescFunctionDesc - Class in org.apache.hadoop.hive.ql.plan
DescFunctionDesc.
DescFunctionDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
DescFunctionDesc(Path) - Constructor for class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
DescFunctionDesc(Path, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
describeTable(DataOutputStream, String, String, Table, Partition, List<FieldSchema>, boolean, boolean, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.formatting.JsonMetaDataFormatter
Describe table.
describeTable(DataOutputStream, String, String, Table, Partition, List<FieldSchema>, boolean, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatter
Describe table.
Description - Annotation Type in org.apache.hadoop.hive.ql.exec
Description.
DescTableDesc - Class in org.apache.hadoop.hive.ql.plan
DescTableDesc.
DescTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
DescTableDesc(Path, String, Map<String, String>, String) - Constructor for class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
deserialize(InputStream) - Static method in class org.apache.hadoop.hive.ql.exec.PTFUtils
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedColumnarSerDe
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSerde
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe
 
DESERIALIZE_PLAN - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
deserializeDeltas(Path, List<Long>) - Static method in class org.apache.hadoop.hive.ql.io.AcidUtils
Convert the list of begin/end transaction id pairs to a list of delta directories.
deserializeExpression(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
deserializeExpressionFromKryo(byte[]) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Deserializes expression from Kryo.
deserializePlan(InputStream, Class<T>, Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Deserializes the plan.
deserializeVector(Object, int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedColumnarSerDe
Deserializes the rowBlob into Vectorized row batch
deserializeVector(Object, int, VectorizedRowBatch) - Method in interface org.apache.hadoop.hive.ql.exec.vector.VectorizedSerde
 
deserializeVector(Object, int, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSerde
 
DEST_DFS_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
DEST_INVALID - Static variable in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
DEST_LOCAL_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
DEST_PARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
DEST_REDUCE - Static variable in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
DEST_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
destroy() - Method in class org.apache.hadoop.hive.ql.Driver
 
destroy() - Method in class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
destroy() - Method in interface org.apache.hadoop.hive.ql.security.HiveAuthenticationProvider
 
destroy() - Method in class org.apache.hadoop.hive.ql.security.SessionStateConfigUserAuthenticator
 
destroy() - Method in class org.apache.hadoop.hive.ql.security.SessionStateUserAuthenticator
 
detachSession() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
determineAlterTableWriteType(AlterTableDesc.AlterTableTypes) - Static method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
Determine the type of lock to request for a given alter table type.
DFS_RESULT_HEADER - Static variable in class org.apache.hadoop.hive.ql.processors.DfsProcessor
 
DfsProcessor - Class in org.apache.hadoop.hive.ql.processors
DfsProcessor.
DfsProcessor(Configuration) - Constructor for class org.apache.hadoop.hive.ql.processors.DfsProcessor
 
DfsProcessor(Configuration, boolean) - Constructor for class org.apache.hadoop.hive.ql.processors.DfsProcessor
 
Dimension - Class in org.apache.hadoop.hive.ql.metadata
Hive consists of a fixed, well defined set of Dimensions.
Dimension(Class<?>, String) - Constructor for class org.apache.hadoop.hive.ql.metadata.Dimension
 
directDecompress(ByteBuffer, ByteBuffer) - Method in interface org.apache.hadoop.hive.ql.io.orc.DirectDecompressionCodec
 
DirectDecompressionCodec - Interface in org.apache.hadoop.hive.ql.io.orc
 
disableOpt() - Method in class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
DisallowTransformHook - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
 
DisallowTransformHook() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.DisallowTransformHook
 
disconnect(BaseWork, BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
disconnect removes an edge between a and b.
dispatch(Node, Stack<Node>) - Method in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
Dispatch the current operator.
dispatch(Node, Stack<Node>, Object...) - Method in class org.apache.hadoop.hive.ql.lib.DefaultRuleDispatcher
Dispatcher function.
dispatch(Node, Stack<Node>, Object...) - Method in interface org.apache.hadoop.hive.ql.lib.Dispatcher
Dispatcher function.
dispatch(Node, Stack<Node>, TaskGraphWalker.TaskGraphWalkerContext) - Method in class org.apache.hadoop.hive.ql.lib.TaskGraphWalker
Dispatch the current operator.
dispatch(Node, Stack<Node>) - Method in class org.apache.hadoop.hive.ql.lib.TaskGraphWalker
 
dispatch(Node, Stack<Node>, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.AbstractJoinTaskDispatcher
 
dispatch(Node, Stack<Node>, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.CrossProductCheck
 
dispatch(Node, Stack<Node>, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.index.IndexWhereTaskDispatcher
 
dispatchAndReturn(Node, Stack<Node>) - Method in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
Returns dispatch result
Dispatcher - Interface in org.apache.hadoop.hive.ql.lib
Dispatcher interface for Operators Used in operator graph walking to dispatch process/visitor functions for operators.
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveLexerX
 
divideBy(RelOptCost) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCost
 
divideChecked(int, Decimal128, Decimal128, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
DO_AUTHORIZATION - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
doCheckCompatibility(String, String, String) - Static method in class org.apache.hadoop.hive.ql.parse.EximUtil
 
doClose() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
doClose() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveRecordReader
 
doClose() - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
Close this InputSplit to future operations.
doClose() - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
doGetAliasesFromPath(Map<String, ArrayList<String>>, Path) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
Get the list of aliases from the opeerator tree that are needed for the path
doGetSplits(JobConf, int) - Method in class org.apache.hadoop.hive.ql.index.HiveIndexedInputFormat
 
doGetWorksFromPath(Map<String, ArrayList<String>>, Map<String, Operator<? extends OperatorDesc>>, Path) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
Get the list of operators from the operator tree that are needed for the path
done() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
done() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
doNext(K, V) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
doNext(K, V) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveRecordReader
 
doNext(K, V) - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
doNext(K, V) - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
doPhase1(ASTNode, QB, SemanticAnalyzer.Phase1Ctx) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
Phase 1: (including, but not limited to): 1.
doPhase1QBExpr(ASTNode, QBExpr, String, String) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
doReset(GenericUDAFAverage.AverageAggregationBuffer<HiveDecimal>) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDecimal
 
doReset(GenericUDAFAverage.AverageAggregationBuffer<Double>) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDouble
 
DosToUnix - Class in org.apache.hadoop.hive.ql.util
 
DosToUnix() - Constructor for class org.apache.hadoop.hive.ql.util.DosToUnix
 
DoubleColumnInList - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Output a boolean value indicating if a column is IN a list of constants.
DoubleColumnInList(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.DoubleColumnInList
 
DoubleColumnInList() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.DoubleColumnInList
 
DoubleColumnStatistics - Interface in org.apache.hadoop.hive.ql.io.orc
Statistics for float and double columns.
DoubleColumnVector - Class in org.apache.hadoop.hive.ql.exec.vector
This class represents a nullable double precision floating point column vector.
DoubleColumnVector() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.DoubleColumnVector
Use this constructor by default.
DoubleColumnVector(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.DoubleColumnVector
Don't use this except for testing purposes.
DoubleNumDistinctValueEstimator - Class in org.apache.hadoop.hive.ql.udf.generic
 
DoubleNumDistinctValueEstimator(int) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.DoubleNumDistinctValueEstimator
 
DoubleNumDistinctValueEstimator(String, int) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.DoubleNumDistinctValueEstimator
 
doubleToTimestamp(double) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
downloadResource(String, boolean) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
Driver - Class in org.apache.hadoop.hive.ql
 
Driver(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.Driver
for backwards compatibility with current tests
Driver(HiveConf, String) - Constructor for class org.apache.hadoop.hive.ql.Driver
 
Driver() - Constructor for class org.apache.hadoop.hive.ql.Driver
 
DRIVER_EXECUTE - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
DRIVER_RUN - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
DriverContext - Class in org.apache.hadoop.hive.ql
DriverContext.
DriverContext() - Constructor for class org.apache.hadoop.hive.ql.DriverContext
 
DriverContext(Context) - Constructor for class org.apache.hadoop.hive.ql.DriverContext
 
DriverTestHook - Class in org.apache.hadoop.hive.ql.hooks
 
DriverTestHook() - Constructor for class org.apache.hadoop.hive.ql.hooks.DriverTestHook
 
DROP - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
dropDatabase(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Drop a database.
dropDatabase(String, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Drop a database
dropDatabase(String, boolean, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Drop a database
DropDatabaseDesc - Class in org.apache.hadoop.hive.ql.plan
DropDatabaseDesc.
DropDatabaseDesc(String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.DropDatabaseDesc
 
DropDatabaseDesc(String, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.DropDatabaseDesc
 
dropFunction(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
DropFunctionDesc - Class in org.apache.hadoop.hive.ql.plan
DropFunctionDesc.
DropFunctionDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DropFunctionDesc
For serialization only.
DropFunctionDesc(String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.DropFunctionDesc
 
dropIndex(String, String, String, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
DropIndexDesc - Class in org.apache.hadoop.hive.ql.plan
 
DropIndexDesc(String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.DropIndexDesc
 
DropMacroDesc - Class in org.apache.hadoop.hive.ql.plan
DropMacroDesc.
DropMacroDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DropMacroDesc
For serialization only.
DropMacroDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.DropMacroDesc
 
dropPartition(String, List<String>, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
dropPartition(String, String, List<String>, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
dropPartitions(String, List<DropTableDesc.PartSpec>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
dropPartitions(String, String, List<DropTableDesc.PartSpec>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
dropRole(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
dropRole(String) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessController
 
dropRole(String) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
Drop role
dropRole(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
dropRole(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
dropTable(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Drops table along with the data in it.
dropTable(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Drops table along with the data in it.
dropTable(String, String, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Drops the table.
DropTableDesc - Class in org.apache.hadoop.hive.ql.plan
DropTableDesc.
DropTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
DropTableDesc(String, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
DropTableDesc(String, Map<Integer, List<ExprNodeGenericFuncDesc>>, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
DropTableDesc.PartSpec - Class in org.apache.hadoop.hive.ql.plan
 
DropTableDesc.PartSpec(ExprNodeGenericFuncDesc, int) - Constructor for class org.apache.hadoop.hive.ql.plan.DropTableDesc.PartSpec
 
DUMMY_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
DUMMY_TABLE - Static variable in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
DummyPartition - Class in org.apache.hadoop.hive.ql.metadata
A Hive Table Partition: is a fundamental storage unit within a Table.
DummyPartition() - Constructor for class org.apache.hadoop.hive.ql.metadata.DummyPartition
 
DummyPartition(Table, String) - Constructor for class org.apache.hadoop.hive.ql.metadata.DummyPartition
 
DummyPartition(Table, String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.metadata.DummyPartition
 
DummyStoreDesc - Class in org.apache.hadoop.hive.ql.plan
Dummy Store Desc.
DummyStoreDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DummyStoreDesc
 
DummyStoreOperator - Class in org.apache.hadoop.hive.ql.exec
For SortMerge joins, this is a dummy operator, which stores the row for the small table before it reaches the sort merge join operator.
DummyStoreOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.DummyStoreOperator
 
dump(int) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
dump(int, HashSet<Integer>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
dump() - Method in class org.apache.hadoop.hive.ql.parse.ASTNode
 
duplicateTo(VectorHashKeyWrapper) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
dupNode() - Method in class org.apache.hadoop.hive.ql.parse.ASTNode
 
DynamicPartitionCtx - Class in org.apache.hadoop.hive.ql.plan
 
DynamicPartitionCtx() - Constructor for class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
DynamicPartitionCtx(Table, Map<String, String>, String, int) - Constructor for class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
DynamicPartitionCtx(DynamicPartitionCtx) - Constructor for class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 

E

EmbeddedLockManager - Class in org.apache.hadoop.hive.ql.lockmgr
shared lock manager for dedicated hive server.
EmbeddedLockManager() - Constructor for class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
ENABLE_INDEXES - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcFile
Deprecated. 
enableOpt(int) - Method in class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
end() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.ArrayWritableGroupConverter
 
end() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.DataWritableGroupConverter
 
end() - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Builder
Finish the current operation and pop it off of the stack.
endGroup() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
Forward a record of join results.
endGroup() - Method in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
endGroup() - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
endGroup() - Method in class org.apache.hadoop.hive.ql.exec.JoinOperator
Forward a record of join results.
endGroup() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
endGroup() - Method in class org.apache.hadoop.hive.ql.exec.MuxOperator
 
endGroup() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
endOfFile - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
endQuery(String) - Method in interface org.apache.hadoop.hive.ql.history.HiveHistory
Called at the end of a query
endQuery(String) - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
 
endTask(String, Task<? extends Serializable>) - Method in interface org.apache.hadoop.hive.ql.history.HiveHistory
Called at the end of a task.
endTask(String, Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
 
EnforceReadOnlyTables - Class in org.apache.hadoop.hive.ql.hooks
Implementation of a pre execute hook that prevents modifications of read-only tables used by the test framework
EnforceReadOnlyTables() - Constructor for class org.apache.hadoop.hive.ql.hooks.EnforceReadOnlyTables
 
Entity - Class in org.apache.hadoop.hive.ql.hooks
This class encapsulates an object that is being read or written to by the query.
Entity() - Constructor for class org.apache.hadoop.hive.ql.hooks.Entity
Only used by serialization.
Entity(Database, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.Entity
Constructor for a database.
Entity(Table, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.Entity
Constructor for a table.
Entity(Partition, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.Entity
Constructor for a partition.
Entity(DummyPartition, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.Entity
 
Entity(String, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.Entity
 
Entity.Type - Enum in org.apache.hadoop.hive.ql.hooks
The type of the entity.
entrySet() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
entrySet() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer
 
entrySet() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo
Gets the entry set on this structure.
ENV_PREFIX - Static variable in class org.apache.hadoop.hive.ql.processors.SetProcessor
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.errors.ErrorAndSolution
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyBytes
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyObject
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Descriptor
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.hooks.Entity
Equals function.
equals(Object) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DependencyKey
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
Equals function.
equals(Object) - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
Equals function.
equals(Object) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcStruct
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveArrayInspector
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BinaryWritable
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.io.RecordIdentifier
 
equals(String, Object) - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Builder
Add an equals leaf to the current item on the stack.
equals(Object) - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.metadata.Dimension
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.metadata.Sample
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
equals(RelOptCost) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCost
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.parse.InputSignature
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderExpression
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderSpec
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionExpression
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitioningSpec
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionSpec
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc.ExprNodeDescEqualityWrapper
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrincipal
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilege
 
err - Variable in class org.apache.hadoop.hive.ql.session.SessionState
 
error(OutputStream, String, int, String) - Method in class org.apache.hadoop.hive.ql.metadata.formatting.JsonMetaDataFormatter
Write an error message.
error(OutputStream, String, int, String, String) - Method in class org.apache.hadoop.hive.ql.metadata.formatting.JsonMetaDataFormatter
 
error(OutputStream, String, int, String) - Method in interface org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatter
Write an error message.
error(OutputStream, String, int, String, String) - Method in interface org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatter
 
ErrorAndSolution - Class in org.apache.hadoop.hive.ql.exec.errors
Immutable class for storing a possible error and a resolution suggestion.
ErrorHeuristic - Interface in org.apache.hadoop.hive.ql.exec.errors
Classes implementing ErrorHeuristic are able to generate a possible cause and solution for Hive jobs that have failed by examining the query, task log files, and the job configuration.
ErrorMsg - Enum in org.apache.hadoop.hive.ql
List of all error messages.
escapeSqlLike(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Escape the '_', '%', as well as the escape characters inside the string key.
escapeString(String) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
escapeText(Text) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
estimate(JobConf, TableScanOperator, long) - Method in interface org.apache.hadoop.hive.ql.metadata.InputEstimator
Estimate input size based on filter and projection on table scan operator
estimate() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator.BinaryStatsAgg
 
estimate() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator.BooleanStatsAgg
 
estimate() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator.DecimalStatsAgg
 
estimate() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.DoubleStatsAgg
 
estimate() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.LongStatsAgg
 
estimate() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg
 
estimate() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator.AbstractAggregationBuffer
Estimate the size of memory which is occupied by aggregation buffer.
estimateNumberOfReducers(HiveConf, ContentSummary, MapWork, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Estimate the number of reducers needed for this job, based on job input, and configuration parameters.
estimateNumDistinctValues() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
estimateNumDistinctValuesPCSA() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
estimateReducers(long, long, int, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
estimateRowSizeFromSchema(HiveConf, List<ColumnInfo>, List<String>) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
 
estimateSelectivity(RexNode) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.stats.FilterSelectivityEstimator
 
ETypeConverter - Enum in org.apache.hadoop.hive.ql.io.parquet.convert
ETypeConverter is an easy way to set the converter for the right type.
eval(String, String, QName) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil
 
evalBoolean(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil
 
evalExprWithPart(ExprNodeDesc, Partition, List<VirtualColumn>, StructObjectInspector) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartExprEvalUtils
Evaluate expression with partition columns
evalNode(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil
 
evalNodeList(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil
 
evalNumber(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil
 
evalString(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil
 
evaluate(Object) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToDecimal
Cast decimal(p1, s1) to decimal(p2, s2).
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToDate
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDate
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDecimal
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColAndCol
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColOrCol
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalColumnInList
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalToStringUnaryUDF
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DoubleColumnInList
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColAndScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColOrScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterConstantBooleanVectorExpression
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDecimalColumnInList
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDoubleColumnInList
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterExprAndExpr
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterExprOrExpr
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterLongColumnInList
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarAndColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarOrColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStringColumnInList
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDoubleToDecimal
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToDecimal
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToString
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRand
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRandNoSeed
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRoundWithNumDigitsDecimalToDecimal
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IdentityExpression
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNotNull
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNull
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColumnInList
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarDivideLongColumn
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongToStringUnaryUDF
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncDoubleToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToDouble
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NotCol
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsFalse
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNotNull
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNull
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsTrue
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringColumnInList
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColCol
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatScalarCol
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringLength
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStart
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStartLen
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDF
 
evaluate(Text) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDF.IUDFUnaryString
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDFDirect
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorCoalesce
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression
This is the primary method to implement expression logic.
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColCol
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldString
 
evaluate(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
evaluate(SearchArgument.TruthValue[]) - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument
Evaluate the entire predicate based on the values for the leaf predicates.
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.AbstractGenericUDFEWAHBitmapBop
 
evaluate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
This function will be called by GroupByOperator when it sees a new input row.
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
Evaluate the GenericUDF with the arguments.
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFAbs
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFArray
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFArrayContains
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFAssertTrue
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBasePad
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseTrim
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBetween
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCase
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCoalesce
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcat
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcatWS
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDate
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateAdd
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateDiff
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateSub
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDecode
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFElt
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFEncode
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFEWAHBitmapEmpty
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFField
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFloorCeilBase
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFormatNumber
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFromUtcTimestamp
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFHash
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIf
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIn
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIndex
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFInFile
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFInstr
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLocate
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLower
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMap
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMapKeys
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMapValues
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFNamedStruct
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFNvl
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPAnd
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqual
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualNS
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualOrGreaterThan
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualOrLessThan
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPGreaterThan
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPLessThan
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNegative
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNot
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotEqual
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotNull
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNull
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPOr
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPPositive
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPower
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPrintf
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFReflect
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFReflect2
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFRound
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSentences
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSize
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSortArray
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSplit
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStringToMap
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStruct
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTimestamp
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToBinary
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToChar
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToDate
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToDecimal
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToUnixTimeStamp
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToVarchar
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTranslate
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUnion
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUnixTimeStamp
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUpper
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFWhen
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.UDFCurrentDB
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFAcos
Take Arc Cosine of a in radians.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFAscii
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFAsin
Take Arc Sine of a in radians.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFAtan
 
evaluate(BytesWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBase64
 
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBin
 
evaluate(Text, IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFConv
Convert numbers between different number bases.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFCos
Take Cosine of a.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFDayOfMonth
Get the day of month from a date string.
evaluate(DateWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFDayOfMonth
 
evaluate(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFDayOfMonth
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFDegrees
 
evaluate() - Method in class org.apache.hadoop.hive.ql.udf.UDFE
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFExp
Raise e (the base of natural logarithm) to the power of a.
evaluate(Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFFindInSet
 
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFFromUnixTime
 
evaluate(LongWritable, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFFromUnixTime
Convert UnixTime to a string format.
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFFromUnixTime
Convert UnixTime to a string format.
evaluate(IntWritable, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFFromUnixTime
Convert UnixTime to a string format.
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFHex
 
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFHex
 
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFHex
Convert every character in s to two hex digits.
evaluate(BytesWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFHex
Convert bytes to a hex string
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFHour
Get the hour from a date string.
evaluate(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFHour
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.UDFJson
Extract json object from a json string based on json path specified, and return json string of the extracted json object.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFLength
 
evaluate(BytesWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLength
 
evaluate(Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFLike
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLn
Returns the natural logarithm of "a".
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLog
Returns the natural logarithm of "a".
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLog
Returns the logarithm of "a" with base "base".
evaluate(DoubleWritable, HiveDecimalWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLog
Get the logarithm of the given decimal with the given base.
evaluate(HiveDecimalWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLog
Get the logarithm of input with the given decimal as the base.
evaluate(HiveDecimalWritable, HiveDecimalWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLog
Get the logarithm of the given decimal input with the given decimal base.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLog10
Returns the logarithm of "a" with base 10.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLog2
Returns the logarithm of "a" with base 2.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFMath
For subclass to implement.
evaluate(HiveDecimalWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFMath
Convert HiveDecimal to a double and call evaluate() on it.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFMinute
Get the minute from a date string.
evaluate(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFMinute
 
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFMonth
Get the month from a date string.
evaluate(DateWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFMonth
 
evaluate(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFMonth
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitAnd
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitAnd
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitAnd
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitAnd
 
evaluate(ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitNot
 
evaluate(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitNot
 
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitNot
 
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitNot
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitOr
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitOr
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitOr
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitOr
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitXor
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitXor
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitXor
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitXor
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPLongDivide
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.UDFParseUrl
 
evaluate(String, String, String) - Method in class org.apache.hadoop.hive.ql.udf.UDFParseUrl
 
evaluate() - Method in class org.apache.hadoop.hive.ql.udf.UDFPI
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFRadians
 
evaluate() - Method in class org.apache.hadoop.hive.ql.udf.UDFRand
 
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFRand
 
evaluate(Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFRegExp
 
evaluate(String, String, Integer) - Method in class org.apache.hadoop.hive.ql.udf.UDFRegExpExtract
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.UDFRegExpExtract
 
evaluate(Text, Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFRegExpReplace
 
evaluate(Text, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFRepeat
 
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFReverse
 
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFSecond
Get the minute from a date string.
evaluate(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSecond
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSign
Take sign of a
evaluate(HiveDecimalWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSign
Get the sign of the decimal input
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSin
Take Sine of a.
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSpace
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSqrt
Return NULL for NULL or negative inputs; otherwise, return the square root.
evaluate(Text, IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSubstr
 
evaluate(Text, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSubstr
 
evaluate(BytesWritable, IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSubstr
 
evaluate(BytesWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSubstr
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFTan
Take Tangent of a
evaluate(NullWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToBoolean
Convert a void to boolean.
evaluate(ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToBoolean
Convert from a byte to boolean.
evaluate(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToBoolean
Convert from a short to boolean.
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToBoolean
Convert from a integer to boolean.
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToBoolean
Convert from a long to boolean.
evaluate(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToBoolean
Convert from a float to boolean.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToBoolean
Convert from a double to boolean.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFToBoolean
Convert from a string to boolean.
evaluate(DateWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToBoolean
 
evaluate(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToBoolean
 
evaluate(HiveDecimalWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToBoolean
 
evaluate(NullWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToByte
Convert from void to a byte.
evaluate(BooleanWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToByte
Convert from boolean to a byte.
evaluate(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToByte
Convert from short to a byte.
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToByte
Convert from integer to a byte.
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToByte
Convert from long to a byte.
evaluate(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToByte
Convert from float to a byte.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToByte
Convert from double to a byte.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFToByte
Convert from string to a byte.
evaluate(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToByte
 
evaluate(HiveDecimalWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToByte
 
evaluate(NullWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDouble
Convert from void to a double.
evaluate(BooleanWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDouble
Convert from boolean to a double.
evaluate(ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDouble
Convert from boolean to a double.
evaluate(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDouble
Convert from short to a double.
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDouble
Convert from integer to a double.
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDouble
Convert from long to a double.
evaluate(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDouble
Convert from float to a double.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDouble
Convert from string to a double.
evaluate(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDouble
 
evaluate(HiveDecimalWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDouble
 
evaluate(NullWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToFloat
Convert from void to a float.
evaluate(BooleanWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToFloat
Convert from boolean to a float.
evaluate(ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToFloat
Convert from byte to a float.
evaluate(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToFloat
Convert from short to a float.
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToFloat
Convert from integer to a float.
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToFloat
Convert from long to a float.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToFloat
Convert from double to a float.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFToFloat
Convert from string to a float.
evaluate(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToFloat
 
evaluate(HiveDecimalWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToFloat
 
evaluate(NullWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToInteger
Convert from void to an integer.
evaluate(BooleanWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToInteger
Convert from boolean to an integer.
evaluate(ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToInteger
Convert from byte to an integer.
evaluate(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToInteger
Convert from short to an integer.
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToInteger
Convert from long to an integer.
evaluate(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToInteger
Convert from float to an integer.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToInteger
Convert from double to an integer.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFToInteger
Convert from string to an integer.
evaluate(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToInteger
Convert from Timestamp to an integer.
evaluate(HiveDecimalWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToInteger
 
evaluate(NullWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToLong
Convert from void to a long.
evaluate(BooleanWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToLong
Convert from boolean to a long.
evaluate(ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToLong
Convert from byte to a long.
evaluate(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToLong
Convert from short to a long.
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToLong
Convert from integer to a long.
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToLong
Convert from long to a long.
evaluate(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToLong
Convert from float to a long.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToLong
Convert from double to a long.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFToLong
Convert from string to a long.
evaluate(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToLong
 
evaluate(HiveDecimalWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToLong
 
evaluate(NullWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToShort
Convert from void to a short.
evaluate(BooleanWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToShort
Convert from boolean to a short.
evaluate(ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToShort
Convert from byte to a short.
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToShort
Convert from integer to a short.
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToShort
Convert from long to a short.
evaluate(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToShort
Convert from float to a short.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToShort
Convert from double to a short.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFToShort
Convert from string to a short.
evaluate(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToShort
 
evaluate(HiveDecimalWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToShort
 
evaluate(NullWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToString
 
evaluate(BooleanWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToString
 
evaluate(ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToString
 
evaluate(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToString
 
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToString
 
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToString
 
evaluate(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToString
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToString
 
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFToString
 
evaluate(DateWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToString
 
evaluate(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToString
 
evaluate(HiveDecimalWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToString
 
evaluate(BytesWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFToString
 
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFUnbase64
 
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFUnhex
Convert every two hex digits in s into.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFWeekOfYear
Get the week of the year from a date string.
evaluate(DateWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFWeekOfYear
 
evaluate(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFWeekOfYear
 
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFYear
Get the year from a date string.
evaluate(DateWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFYear
 
evaluate(TimestampWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFYear
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.xml.GenericUDFXPath
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathBoolean
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathDouble
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathFloat
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathInteger
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathLong
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathShort
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathString
 
evaluateBatch(VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapperBatch
Processes a batch: Evaluates each key vector expression. Copies out each key's primitive values into the key wrappers computes the hashcode of the key wrappers
evaluateExprOnPart(ObjectPair<PrimitiveObjectInspector, ExprNodeEvaluator>, Object) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartExprEvalUtils
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorAggregateExpression
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFAvgDecimal
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCount
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCountStar
 
evaluateOutput(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFSumDecimal
 
exchangeTablePartitions(Map<String, String>, String, String, String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
EXCLUDE - Static variable in class org.apache.hadoop.hive.ql.exec.TopNHash
 
ExecDriver - Class in org.apache.hadoop.hive.ql.exec.mr
ExecDriver is the central class in co-ordinating execution of any map-reduce task.
ExecDriver() - Constructor for class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
Constructor when invoked from QL.
ExecDriver(MapredWork, JobConf, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
Constructor/Initialization for invocation as independent utility.
ExecMapper - Class in org.apache.hadoop.hive.ql.exec.mr
ExecMapper is the generic Map class for Hive.
ExecMapper() - Constructor for class org.apache.hadoop.hive.ql.exec.mr.ExecMapper
 
ExecMapper.reportStats - Class in org.apache.hadoop.hive.ql.exec.mr
reportStats.
ExecMapper.reportStats(Reporter) - Constructor for class org.apache.hadoop.hive.ql.exec.mr.ExecMapper.reportStats
 
ExecMapperContext - Class in org.apache.hadoop.hive.ql.exec.mr
 
ExecMapperContext() - Constructor for class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
ExecReducer - Class in org.apache.hadoop.hive.ql.exec.mr
ExecReducer is the generic Reducer class for Hive.
ExecReducer() - Constructor for class org.apache.hadoop.hive.ql.exec.mr.ExecReducer
 
execute() - Method in class org.apache.hadoop.hive.ql.Driver
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.ColumnStatsTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.CopyTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.DDLTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.DependencyCollectionTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.FunctionTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.MoveTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
Execute a query plan using Hadoop.
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.mr.MapRedTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.StatsNoJobTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.StatsTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.BlockMergeTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateTask
 
execute(PTFPartition) - Method in class org.apache.hadoop.hive.ql.udf.ptf.Noop
 
execute(PTFPartition) - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMap
 
execute(PTFPartition) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
execute(PTFPartition.PTFPartitionIterator<Object>, PTFPartition) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction
 
executeFromChildJVM(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
executeTask() - Method in class org.apache.hadoop.hive.ql.exec.Task
This method is called in the Driver on every task.
ExecuteWithHookContext - Interface in org.apache.hadoop.hive.ql.hooks
ExecuteWithHookContext is a new interface that the Pre/Post Execute Hook can run with the HookContext.
executeWithRetry(Utilities.SQLCommand<T>, PreparedStatement, int, int) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Retry SQL execution with random backoff (same as the one implemented in HDFS-767).
EximUtil - Class in org.apache.hadoop.hive.ql.parse
EximUtil.
exists(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
existsTable() - Method in class org.apache.hadoop.hive.ql.parse.ImportSemanticAnalyzer
 
EXPL_COLUMN_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
Explain - Annotation Type in org.apache.hadoop.hive.ql.plan
Explain.
explainNoCompute() - Method in class org.apache.hadoop.hive.ql.plan.SelectDesc
 
ExplainSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
ExplainSemanticAnalyzer.
ExplainSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.ExplainSemanticAnalyzer
 
ExplainTask - Class in org.apache.hadoop.hive.ql.exec
ExplainTask implementation.
ExplainTask() - Constructor for class org.apache.hadoop.hive.ql.exec.ExplainTask
 
ExplainTask.MethodComparator - Class in org.apache.hadoop.hive.ql.exec
MethodComparator.
ExplainTask.MethodComparator() - Constructor for class org.apache.hadoop.hive.ql.exec.ExplainTask.MethodComparator
 
ExplainWork - Class in org.apache.hadoop.hive.ql.plan
ExplainWork.
ExplainWork() - Constructor for class org.apache.hadoop.hive.ql.plan.ExplainWork
 
ExplainWork(Path, ParseContext, List<Task<? extends Serializable>>, Task<? extends Serializable>, String, HashSet<ReadEntity>, boolean, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.ExplainWork
 
ExplosionDesc - Class in org.apache.hadoop.hive.ql.plan
ExplosionDesc.
ExplosionDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExplosionDesc
 
ExplosionDesc(String, int) - Constructor for class org.apache.hadoop.hive.ql.plan.ExplosionDesc
 
ExportSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
ExportSemanticAnalyzer.
ExportSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.ExportSemanticAnalyzer
 
ExprNodeColumnDesc - Class in org.apache.hadoop.hive.ql.plan
ExprNodeColumnDesc.
ExprNodeColumnDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
ExprNodeColumnDesc(TypeInfo, String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
ExprNodeColumnDesc(Class<?>, String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
ExprNodeColumnDesc(TypeInfo, String, String, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
ExprNodeColumnEvaluator - Class in org.apache.hadoop.hive.ql.exec
This evaluator gets the column from the row object.
ExprNodeColumnEvaluator(ExprNodeColumnDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeColumnEvaluator
 
ExprNodeColumnListDesc - Class in org.apache.hadoop.hive.ql.plan
Dummy desc only for populating TOK_ALLCOLREF and should not be used outside of TypeCheckProcFactory
ExprNodeColumnListDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeColumnListDesc
 
ExprNodeConstantDesc - Class in org.apache.hadoop.hive.ql.plan
A constant expression.
ExprNodeConstantDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
ExprNodeConstantDesc(TypeInfo, Object) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
ExprNodeConstantDesc(Object) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
ExprNodeConstantEvaluator - Class in org.apache.hadoop.hive.ql.exec
ExprNodeConstantEvaluator.
ExprNodeConstantEvaluator(ExprNodeConstantDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeConstantEvaluator
 
ExprNodeDesc - Class in org.apache.hadoop.hive.ql.plan
ExprNodeDesc.
ExprNodeDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
ExprNodeDesc(TypeInfo) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
ExprNodeDesc.ExprNodeDescEqualityWrapper - Class in org.apache.hadoop.hive.ql.plan
 
ExprNodeDesc.ExprNodeDescEqualityWrapper(ExprNodeDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeDesc.ExprNodeDescEqualityWrapper
 
ExprNodeDescUtils - Class in org.apache.hadoop.hive.ql.plan
 
ExprNodeDescUtils() - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
 
ExprNodeEvaluator<T extends ExprNodeDesc> - Class in org.apache.hadoop.hive.ql.exec
ExprNodeEvaluator.
ExprNodeEvaluator(T) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
 
ExprNodeEvaluatorFactory - Class in org.apache.hadoop.hive.ql.exec
ExprNodeEvaluatorFactory.
ExprNodeEvaluatorHead - Class in org.apache.hadoop.hive.ql.exec
Increases version number of each evaluations for correct caching
ExprNodeEvaluatorHead(ExprNodeEvaluator) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluatorHead
 
ExprNodeEvaluatorRef - Class in org.apache.hadoop.hive.ql.exec
Returns evaluation result of other evaluator
ExprNodeEvaluatorRef(ExprNodeEvaluator) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluatorRef
 
ExprNodeFieldDesc - Class in org.apache.hadoop.hive.ql.plan
ExprNodeFieldDesc.
ExprNodeFieldDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
ExprNodeFieldDesc(TypeInfo, ExprNodeDesc, String, Boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
ExprNodeFieldEvaluator - Class in org.apache.hadoop.hive.ql.exec
This Evaluator can evaluate s.f for s as both struct and list of struct.
ExprNodeFieldEvaluator(ExprNodeFieldDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeFieldEvaluator
 
ExprNodeGenericFuncDesc - Class in org.apache.hadoop.hive.ql.plan
Describes a GenericFunc node.
ExprNodeGenericFuncDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
ExprNodeGenericFuncDesc(TypeInfo, GenericUDF, String, List<ExprNodeDesc>) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
ExprNodeGenericFuncDesc(ObjectInspector, GenericUDF, String, List<ExprNodeDesc>) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
ExprNodeGenericFuncDesc(TypeInfo, GenericUDF, List<ExprNodeDesc>) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
ExprNodeGenericFuncDesc(ObjectInspector, GenericUDF, List<ExprNodeDesc>) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
ExprNodeGenericFuncEvaluator - Class in org.apache.hadoop.hive.ql.exec
ExprNodeGenericFuncEvaluator.
ExprNodeGenericFuncEvaluator(ExprNodeGenericFuncDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeGenericFuncEvaluator
 
ExprNodeNullDesc - Class in org.apache.hadoop.hive.ql.plan
ExprNodeNullDesc.
ExprNodeNullDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeNullDesc
 
ExprNodeNullEvaluator - Class in org.apache.hadoop.hive.ql.exec
ExprNodeNullEvaluator.
ExprNodeNullEvaluator(ExprNodeNullDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeNullEvaluator
 
ExprProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.lineage
The processor context for the lineage information.
ExprProcCtx(LineageCtx, Operator<? extends OperatorDesc>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcCtx
Constructor.
ExprProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.ppr
The processor context for partition pruner.
ExprProcCtx(String) - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcCtx
 
ExprProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Expression processor factory for lineage.
ExprProcFactory() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory
 
ExprProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.ppr
Expression processor factory for partition pruning.
ExprProcFactory.ColumnExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for column expressions.
ExprProcFactory.ColumnExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory.ColumnExprProcessor
 
ExprProcFactory.DefaultExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for constants and null expressions.
ExprProcFactory.DefaultExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory.DefaultExprProcessor
 
ExprProcFactory.GenericExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for any function or field expression.
ExprProcFactory.GenericExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory.GenericExprProcessor
 
ExprProcFactory.PPRColumnExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.ppr
Processor for ppr column expressions.
ExprProcFactory.PPRColumnExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory.PPRColumnExprProcessor
 
ExprPrunerInfo - Class in org.apache.hadoop.hive.ql.optimizer.ppr
The processor context for partition pruner.
ExprPrunerInfo() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.ExprPrunerInfo
 
ExprWalkerInfo - Class in org.apache.hadoop.hive.ql.ppd
Context for Expression Walker for determining predicate pushdown candidates It contains a ExprInfo object for each expression that is processed.
ExprWalkerInfo() - Constructor for class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
ExprWalkerInfo(Operator<? extends OperatorDesc>, RowResolver) - Constructor for class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
ExprWalkerProcFactory - Class in org.apache.hadoop.hive.ql.ppd
Expression factory for predicate pushdown processing.
ExprWalkerProcFactory.ColumnExprProcessor - Class in org.apache.hadoop.hive.ql.ppd
ColumnExprProcessor.
ExprWalkerProcFactory.ColumnExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory.ColumnExprProcessor
 
ExprWalkerProcFactory.DefaultExprProcessor - Class in org.apache.hadoop.hive.ql.ppd
For constants and null expressions.
ExprWalkerProcFactory.DefaultExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory.DefaultExprProcessor
 
ExprWalkerProcFactory.FieldExprProcessor - Class in org.apache.hadoop.hive.ql.ppd
FieldExprProcessor.
ExprWalkerProcFactory.FieldExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory.FieldExprProcessor
 
ExprWalkerProcFactory.GenericFuncExprProcessor - Class in org.apache.hadoop.hive.ql.ppd
If all children are candidates and refer only to one table alias then this expr is a candidate else it is not a candidate but its children could be final candidates.
ExprWalkerProcFactory.GenericFuncExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory.GenericFuncExprProcessor
 
extendedToString() - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
extractComparePair(ExprNodeDesc, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
 
ExtractDesc - Class in org.apache.hadoop.hive.ql.plan
ExtractDesc.
ExtractDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExtractDesc
 
ExtractDesc(ExprNodeDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.ExtractDesc
 
extractDirectWorks(Map<MapJoinOperator, List<Operator<? extends OperatorDesc>>>) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
extractErrorCode(String[]) - Static method in class org.apache.hadoop.hive.ql.exec.mr.JobDebugger
 
ExtractOperator - Class in org.apache.hadoop.hive.ql.exec
Extract operator implementation Extracts a subobject and passes that on.
ExtractOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.ExtractOperator
 
extractPushdownPreds(OpWalkerInfo, Operator<? extends OperatorDesc>, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory
 
extractPushdownPreds(OpWalkerInfo, Operator<? extends OperatorDesc>, List<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory
Extracts pushdown predicates from the given list of predicate expression.

F

FACTORY - Static variable in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument
Use this instance to create SearchArgument instances.
FACTORY - Static variable in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCost
 
FAILURE_HOOK - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
fetch(List) - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
FetchFormatter<T> - Interface in org.apache.hadoop.hive.ql.exec
internal-use only Used in ListSinkOperator for formatting final output
FetchFormatter.ThriftFormatter - Class in org.apache.hadoop.hive.ql.exec
 
FetchFormatter.ThriftFormatter() - Constructor for class org.apache.hadoop.hive.ql.exec.FetchFormatter.ThriftFormatter
 
FetchOperator - Class in org.apache.hadoop.hive.ql.exec
FetchTask implementation.
FetchOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.FetchOperator
 
FetchOperator(FetchWork, JobConf) - Constructor for class org.apache.hadoop.hive.ql.exec.FetchOperator
 
FetchOperator(FetchWork, JobConf, Operator<?>, List<VirtualColumn>) - Constructor for class org.apache.hadoop.hive.ql.exec.FetchOperator
 
FetchTask - Class in org.apache.hadoop.hive.ql.exec
FetchTask implementation.
FetchTask() - Constructor for class org.apache.hadoop.hive.ql.exec.FetchTask
 
FetchWork - Class in org.apache.hadoop.hive.ql.plan
FetchWork.
FetchWork() - Constructor for class org.apache.hadoop.hive.ql.plan.FetchWork
 
FetchWork(List<List<Object>>, ObjectInspector) - Constructor for class org.apache.hadoop.hive.ql.plan.FetchWork
 
FetchWork(Path, TableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.FetchWork
 
FetchWork(Path, TableDesc, int) - Constructor for class org.apache.hadoop.hive.ql.plan.FetchWork
 
FetchWork(List<Path>, List<PartitionDesc>, TableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.FetchWork
 
FetchWork(List<Path>, List<PartitionDesc>, TableDesc, int) - Constructor for class org.apache.hadoop.hive.ql.plan.FetchWork
 
FIELD_DELIM - Static variable in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatUtils
 
fields - Variable in class org.apache.hadoop.hive.ql.exec.ArchiveUtils.PartSpecInfo
 
FileDump - Class in org.apache.hadoop.hive.ql.io.orc
A tool for printing out the file structure of ORC files.
FILENAME - Static variable in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
FileSinkDesc - Class in org.apache.hadoop.hive.ql.plan
FileSinkDesc.
FileSinkDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
FileSinkDesc(Path, TableDesc, boolean, int, boolean, boolean, int, int, ArrayList<ExprNodeDesc>, DynamicPartitionCtx) - Constructor for class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
FileSinkDesc(Path, TableDesc, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
FileSinkDesc.DPSortState - Enum in org.apache.hadoop.hive.ql.plan
 
FileSinkOperator - Class in org.apache.hadoop.hive.ql.exec
File Sink operator implementation.
FileSinkOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
FileSinkOperator.FSPaths - Class in org.apache.hadoop.hive.ql.exec
 
FileSinkOperator.FSPaths() - Constructor for class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
 
FileSinkOperator.FSPaths(Path) - Constructor for class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
 
FileSinkOperator.RecordWriter - Interface in org.apache.hadoop.hive.ql.exec
RecordWriter.
FileSinkProcessor - Class in org.apache.hadoop.hive.ql.parse
FileSinkProcessor handles addition of merge, move and stats tasks for filesinks
FileSinkProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.FileSinkProcessor
 
fileSinkSet - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
filesystem(FileSystem) - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
Provide a file system to the writer.
filesystem(FileSystem) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.ReaderOptions
 
fileSystem(FileSystem) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
Provide the filesystem for the path, if the client has it available.
fill(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
 
fill(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.DoubleColumnVector
 
fill(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.LongColumnVector
 
FILTER_EXPR_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
FILTER_TEXT_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
FilterColAndScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
FilterColAndScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColAndScalar
 
FilterColAndScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColAndScalar
 
FilterColOrScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
FilterColOrScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColOrScalar
 
FilterColOrScalar(int, long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColOrScalar
 
FilterConstantBooleanVectorExpression - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
FilterConstantBooleanVectorExpression() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterConstantBooleanVectorExpression
 
FilterConstantBooleanVectorExpression(long) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterConstantBooleanVectorExpression
 
FilterDecimalColumnInList - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Evaluate IN filter on a batch for a vector of decimals.
FilterDecimalColumnInList() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDecimalColumnInList
 
FilterDecimalColumnInList(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDecimalColumnInList
After construction you must call setInListValues() to add the values to the IN set.
FilterDesc - Class in org.apache.hadoop.hive.ql.plan
FilterDesc.
FilterDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.FilterDesc
 
FilterDesc(ExprNodeDesc, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.FilterDesc
 
FilterDesc(ExprNodeDesc, boolean, FilterDesc.sampleDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.FilterDesc
 
FilterDesc.sampleDesc - Class in org.apache.hadoop.hive.ql.plan
sampleDesc is used to keep track of the sampling descriptor.
FilterDesc.sampleDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.FilterDesc.sampleDesc
 
FilterDesc.sampleDesc(int, int, List<String>, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.FilterDesc.sampleDesc
 
FilterDoubleColumnInList - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Evaluate IN filter on a batch for a vector of doubles.
FilterDoubleColumnInList() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDoubleColumnInList
 
FilterDoubleColumnInList(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDoubleColumnInList
After construction you must call setInListValues() to add the values to the IN set.
FilterExprAndExpr - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This class represents a non leaf binary operator in the expression tree.
FilterExprAndExpr() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterExprAndExpr
 
FilterExprOrExpr - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This class represents an Or expression.
FilterExprOrExpr() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterExprOrExpr
 
FilterLongColumnInList - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Evaluate IN filter on a batch for a vector of longs.
FilterLongColumnInList() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterLongColumnInList
 
FilterLongColumnInList(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterLongColumnInList
After construction you must call setInListValues() to add the values to the IN set.
filterNulls(ColumnVector, boolean, int[], int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NullUtil
Filter out rows with null values.
FilterOperator - Class in org.apache.hadoop.hive.ql.exec
Filter operator implementation.
FilterOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.FilterOperator
 
FilterOperator.Counter - Enum in org.apache.hadoop.hive.ql.exec
Counter.
filterPartitionsByExpr(List<String>, byte[], String, List<String>) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionExpressionForMetastore
 
FilterScalarAndColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
FilterScalarAndColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarAndColumn
 
FilterScalarAndColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarAndColumn
 
FilterScalarOrColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
FilterScalarOrColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarOrColumn
 
FilterScalarOrColumn(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarOrColumn
 
FilterSelectivityEstimator - Class in org.apache.hadoop.hive.ql.optimizer.optiq.stats
 
FilterStringColLikeStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Evaluate LIKE filter on a batch for a vector of strings.
FilterStringColLikeStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStringColLikeStringScalar
 
FilterStringColLikeStringScalar(int, byte[]) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStringColLikeStringScalar
 
FilterStringColRegExpStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Evaluate REGEXP filter on a batch for a vector of strings.
FilterStringColRegExpStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStringColRegExpStringScalar
 
FilterStringColRegExpStringScalar(int, byte[]) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStringColRegExpStringScalar
 
FilterStringColumnInList - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Evaluate an IN filter on a batch for a vector of strings.
FilterStringColumnInList() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStringColumnInList
 
FilterStringColumnInList(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStringColumnInList
After construction you must call setInListValues() to add the values to the IN set.
finalize() - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
 
find(String[]) - Static method in enum org.apache.hadoop.hive.ql.processors.HiveCommand
 
find_resource_type(String) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
findAlias(MapWork, Operator<?>) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
findAliases(MapWork, Operator<?>) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
findBaseTable(String) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
findMissingPrivs(RequiredPrivileges) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.RequiredPrivileges
Find the missing privileges in availPrivs
findMoveTask(List<Task<MoveWork>>, FileSinkOperator) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
findNode(Stack<Node>, Class<T>) - Static method in class org.apache.hadoop.hive.ql.lib.Utils
Find the first node of a type from ancestor stack, starting from parents.
findOperators(Operator<?>, Class<T>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorUtils
 
findOperators(Collection<Operator<?>>, Class<T>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorUtils
 
findOperatorsUpstream(Operator<?>, Class<T>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorUtils
 
findOperatorsUpstream(Collection<Operator<?>>, Class<T>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorUtils
 
findRootNonNullToken(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.ParseUtils
Performs a descent of the leftmost branch of a tree, stopping when either a node with a non-null token is found or the leaf level is encountered.
findSiblingOperators(Operator<? extends OperatorDesc>) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
Find all sibling operators (which have the same child operator of op) of op (op included).
findSiblingReduceSinkOperators(ReduceSinkOperator) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
Find all sibling ReduceSinkOperators (which have the same child operator of op) of op (op included).
findSingleOperator(Operator<?>, Class<T>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorUtils
 
findSingleOperatorUpstream(Operator<?>, Class<T>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorUtils
 
findSQLState(String) - Static method in enum org.apache.hadoop.hive.ql.ErrorMsg
For a given error message string, searches for a ErrorMsg enum that appears to be a match.
findText(Text, Text, int) - Static method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils
Finds any occurence of subtext from text in the backing buffer, for avoiding string encoding and decoding.
findTopOps(Operator<?>, Class<?>) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
finished(TaskRunner) - Method in class org.apache.hadoop.hive.ql.DriverContext
 
first() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer.RowIterator
 
first() - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
first() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
first() - Method in class org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer
 
first() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
firstItem - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator.DecimalStatsAgg
 
firstItem - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.DoubleStatsAgg
 
firstItem - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.LongStatsAgg
 
firstItem - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg
 
flat(List<List<String>>) - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPruner.DynamicMultiDimensionalCollection
Flat a dynamic-multi-dimension collection.
FlatFileInputFormat<T> - Class in org.apache.hadoop.hive.ql.io
An InputFormat for Plain files with Deserializer records.
FlatFileInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.FlatFileInputFormat
 
FlatFileInputFormat.FlatFileRecordReader<R> - Class in org.apache.hadoop.hive.ql.io
An RecordReader for plain files with Deserializer records Reads one row at a time of type R.
FlatFileInputFormat.FlatFileRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
FlatFileRecordReader constructor constructs the underlying stream (potentially decompressed) and creates the deserializer.
FlatFileInputFormat.RowContainer<T> - Class in org.apache.hadoop.hive.ql.io
A work-around until HADOOP-1230 is fixed.
FlatFileInputFormat.RowContainer() - Constructor for class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.RowContainer
 
FlatFileInputFormat.SerializationContext<S> - Interface in org.apache.hadoop.hive.ql.io
An implementation of SerializationContext is responsible for looking up the Serialization implementation for the given RecordReader.
FlatFileInputFormat.SerializationContextFromConf<S> - Class in org.apache.hadoop.hive.ql.io
An implementation of FlatFileInputFormat.SerializationContext that reads the Serialization class and specific subclass to be deserialized from the JobConf.
FlatFileInputFormat.SerializationContextFromConf() - Constructor for class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
 
flatten(boolean, int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
Simplify vector by brute-force flattening noNulls and isRepeating This can be used to reduce combinatorial explosion of code paths in VectorExpressions with many arguments, at the expense of loss of some performance.
flatten(boolean, int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.ColumnVector
 
flatten(boolean, int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.DecimalColumnVector
 
flatten(boolean, int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.DoubleColumnVector
 
flatten(boolean, int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.LongColumnVector
 
flattenNoNulls(boolean, int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.ColumnVector
 
flattenRepeatingNulls(boolean, int[], int) - Method in class org.apache.hadoop.hive.ql.exec.vector.ColumnVector
 
flip() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
Some functions are affected by appearing order of arguments (comparisons, for example)
flip() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualOrGreaterThan
 
flip() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualOrLessThan
 
flip() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPGreaterThan
 
flip() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPLessThan
 
floor(int, Decimal128, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
flush() - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
Forward all aggregations to children.
flush() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
flush() - Method in class org.apache.hadoop.hive.ql.exec.TopNHash
Flushes all the rows cached in the heap.
flush() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
flush() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater
 
flush() - Method in interface org.apache.hadoop.hive.ql.io.RecordUpdater
Flush the current set of rows to the underlying file system, so that they are available to readers.
flushBlock(RCFile.KeyBuffer, RCFile.ValueBuffer, int, int, int) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Writer
flush a block out without doing anything except compressing the key part.
FooterBuffer - Class in org.apache.hadoop.hive.ql.exec
 
FooterBuffer() - Constructor for class org.apache.hadoop.hive.ql.exec.FooterBuffer
 
format(String) - Method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
format(String...) - Method in enum org.apache.hadoop.hive.ql.ErrorMsg
If the message is parametrized, this will fill the parameters with supplied reasons, otherwise reasons are appended at the end of the message.
formatBinaryString(byte[], int, int) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
formatMsecToStr(long) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Format number of milliseconds to strings
forward(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
forward(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.MuxOperator
 
FORWARD - Static variable in class org.apache.hadoop.hive.ql.exec.TopNHash
 
ForwardDesc - Class in org.apache.hadoop.hive.ql.plan
ForwardDesc.
ForwardDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ForwardDesc
 
ForwardOperator - Class in org.apache.hadoop.hive.ql.exec
Forward Operator Just forwards.
ForwardOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.ForwardOperator
 
forwardUDTFOutput(Object) - Method in class org.apache.hadoop.hive.ql.exec.UDTFOperator
forwardUDTFOutput is typically called indirectly by the GenericUDTF when the GenericUDTF has generated output rows that should be passed on to the next operator(s) in the DAG.
ForwardWalker - Class in org.apache.hadoop.hive.ql.lib
 
ForwardWalker(Dispatcher) - Constructor for class org.apache.hadoop.hive.ql.lib.ForwardWalker
Constructor.
forWindowing() - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
foundAllTargets() - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
Returns true if the current comparison is in the list of stop comparisons, i.e.
free(T) - Method in interface org.apache.hadoop.hive.ql.exec.vector.VectorUtilBatchObjectPool.IAllocator
 
fromBytes(MapJoinKey, boolean, byte[]) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyBytes
 
fromTimestamp(long) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
fromTimestampToDouble(long) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
FSStatsAggregator - Class in org.apache.hadoop.hive.ql.stats.fs
 
FSStatsAggregator() - Constructor for class org.apache.hadoop.hive.ql.stats.fs.FSStatsAggregator
 
FSStatsPublisher - Class in org.apache.hadoop.hive.ql.stats.fs
 
FSStatsPublisher() - Constructor for class org.apache.hadoop.hive.ql.stats.fs.FSStatsPublisher
 
FULL_OUTER_JOIN - Static variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
func(Operator) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapper.reportStats
 
func(Operator<? extends OperatorDesc>) - Method in interface org.apache.hadoop.hive.ql.exec.Operator.OperatorFunc
 
func(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerDoubleToDouble
 
func(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerLongToDouble
 
func(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.RoundWithNumDigitsDoubleToDouble
 
FuncBin - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Vectorized implementation of Bin(long) function that returns string.
FuncBin(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncBin
 
FuncBin() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncBin
 
FuncDecimalToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This is a superclass for unary decimal functions and expressions returning doubles that operate directly on the input and set the output.
FuncDecimalToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToDouble
 
FuncDecimalToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToDouble
 
FuncDecimalToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This is a superclass for unary decimal functions and expressions returning integers that operate directly on the input and set the output.
FuncDecimalToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToLong
 
FuncDecimalToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToLong
 
FuncDoubleToDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This is a superclass for unary double functions and expressions returning decimals that operate directly on the input and set the output.
FuncDoubleToDecimal(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDoubleToDecimal
 
FuncDoubleToDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDoubleToDecimal
 
FuncHex - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
FuncHex(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncHex
 
FuncHex() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncHex
 
FuncLogWithBaseDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
FuncLogWithBaseDoubleToDouble(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLogWithBaseDoubleToDouble
 
FuncLogWithBaseDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLogWithBaseDoubleToDouble
 
FuncLogWithBaseLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
FuncLogWithBaseLongToDouble(double, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLogWithBaseLongToDouble
 
FuncLogWithBaseLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLogWithBaseLongToDouble
 
FuncLongToDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This is a superclass for unary long functions and expressions returning decimals that operate directly on the input and set the output.
FuncLongToDecimal(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToDecimal
 
FuncLongToDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToDecimal
 
FuncLongToString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Superclass to support vectorized functions that take a long and return a string, optionally with additional configuraiton arguments.
FuncPowerDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Vectorized implementation for Pow(a, power) and Power(a, power)
FuncPowerDoubleToDouble(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerDoubleToDouble
 
FuncPowerDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerDoubleToDouble
 
FuncPowerLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Vectorized implementation for Pow(a, power) and Power(a, power)
FuncPowerLongToDouble(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerLongToDouble
 
FuncPowerLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerLongToDouble
 
FuncRand - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Implements vectorized rand(seed) function evaluation.
FuncRand(long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRand
 
FuncRand() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRand
 
FuncRandNoSeed - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Implements vectorized rand() function evaluation.
FuncRandNoSeed(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRandNoSeed
 
FuncRandNoSeed() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRandNoSeed
 
FuncRoundWithNumDigitsDecimalToDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
FuncRoundWithNumDigitsDecimalToDecimal(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRoundWithNumDigitsDecimalToDecimal
 
FuncRoundWithNumDigitsDecimalToDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRoundWithNumDigitsDecimalToDecimal
 
FunctionInfo - Class in org.apache.hadoop.hive.ql.exec
FunctionInfo.
FunctionInfo(boolean, String, GenericUDF) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
FunctionInfo(boolean, String, GenericUDAFResolver) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
FunctionInfo(boolean, String, GenericUDTF) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
FunctionInfo(String, Class<? extends TableFunctionResolver>) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
FunctionRegistry - Class in org.apache.hadoop.hive.ql.exec
FunctionRegistry.
FunctionSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
FunctionSemanticAnalyzer.
FunctionSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.FunctionSemanticAnalyzer
 
FunctionTask - Class in org.apache.hadoop.hive.ql.exec
FunctionTask.
FunctionTask() - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionTask
 
FunctionUtils - Class in org.apache.hadoop.hive.ql.exec
 
FunctionUtils() - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionUtils
 
FunctionUtils.FunctionType - Enum in org.apache.hadoop.hive.ql.exec
Function type, for permanent functions.
FunctionUtils.UDFClassType - Enum in org.apache.hadoop.hive.ql.exec
Enum type to describe what kind of UDF implementation class
FunctionWork - Class in org.apache.hadoop.hive.ql.plan
FunctionWork.
FunctionWork() - Constructor for class org.apache.hadoop.hive.ql.plan.FunctionWork
For serialization only.
FunctionWork(CreateFunctionDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.FunctionWork
 
FunctionWork(DropFunctionDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.FunctionWork
 
FunctionWork(CreateMacroDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.FunctionWork
 
FunctionWork(DropMacroDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.FunctionWork
 

G

genAllExprNodeDesc(ASTNode, RowResolver) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
Generates an expression node descriptors for the expression and children of it with default TypeCheckCtx.
genAllExprNodeDesc(ASTNode, RowResolver, TypeCheckCtx) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
Generates all of the expression node descriptors for the expression and children of it passed in the arguments.
genColLists(HashMap<Operator<? extends OperatorDesc>, OpParseContext>) - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
genColLists(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
Creates the list of internal column names(these names are used in the RowResolver and are different from the external column names) that are needed in the subtree.
generateCmdLine(HiveConf, Context) - Static method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
Given a Hive Configuration object - generate a command line fragment for passing such configuration information to ExecDriver.
generateCollection(List<List<String>>) - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPruner.DynamicMultiDimensionalCollection
Find out complete skewed-element collection For example: 1.
generateErrorMessage(ASTNode, String) - Static method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
generateExecutionId() - Static method in class org.apache.hadoop.hive.ql.Context
Generate a unique executionId.
generateFileName(Byte, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
generateIndexBuildTaskList(Table, Index, List<Partition>, List<Partition>, Table, Set<ReadEntity>, Set<WriteEntity>) - Method in interface org.apache.hadoop.hive.ql.index.HiveIndexHandler
Requests that the handler generate a plan for building the index; the plan should read the base table and write out the index representation.
generateIndexBuildTaskList(Table, Index, List<Partition>, List<Partition>, Table, Set<ReadEntity>, Set<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.index.TableBasedIndexHandler
 
generateIndexQuery(Index, ExprNodeDesc, ParseContext, HiveIndexQueryContext) - Method in class org.apache.hadoop.hive.ql.index.AbstractIndexHandler
 
generateIndexQuery(List<Index>, ExprNodeDesc, ParseContext, HiveIndexQueryContext) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapIndexHandler
 
generateIndexQuery(List<Index>, ExprNodeDesc, ParseContext, HiveIndexQueryContext) - Method in class org.apache.hadoop.hive.ql.index.compact.CompactIndexHandler
 
generateIndexQuery(List<Index>, ExprNodeDesc, ParseContext, HiveIndexQueryContext) - Method in interface org.apache.hadoop.hive.ql.index.HiveIndexHandler
Generate the list of tasks required to run an index optimized sub-query for the given predicate, using the given indexes.
generateMapJoinOperator(ParseContext, JoinOperator, QBJoinTree, int) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
generateMapMetaData() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
generateOperatorTree(HiveConf, String) - Static method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteParseContextGenerator
Parse the input String command and generate a ASTNode tree.
generatePath(Path, String, Byte, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
generatePath(Path, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
generateTarFileName(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
generateTarPath(Path, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
generateTmpPath(Path, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
generateUpdateTasks() - Method in class org.apache.hadoop.hive.ql.parse.IndexUpdater
 
Generator - Class in org.apache.hadoop.hive.ql.optimizer.lineage
This class generates the lineage information for the columns and tables from the plan before it goes through other optimization phases.
Generator() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.Generator
 
GenericUDAFAverage - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFAverage.
GenericUDAFAverage() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage
 
GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator<TYPE> - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
GenericUDAFAverage.GenericUDAFAverageEvaluatorDecimal - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFAverage.GenericUDAFAverageEvaluatorDecimal() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDecimal
 
GenericUDAFAverage.GenericUDAFAverageEvaluatorDouble - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFAverage.GenericUDAFAverageEvaluatorDouble() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDouble
 
GenericUDAFBridge - Class in org.apache.hadoop.hive.ql.udf.generic
This class is a bridge between GenericUDAF and UDAF.
GenericUDAFBridge(UDAF) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge
 
GenericUDAFBridge.GenericUDAFBridgeEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFBridgeEvaluator.
GenericUDAFBridge.GenericUDAFBridgeEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
GenericUDAFBridge.GenericUDAFBridgeEvaluator(Class<? extends UDAFEvaluator>) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
GenericUDAFCollectList - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFCollectList() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCollectList
 
GenericUDAFCollectSet - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFCollectSet
GenericUDAFCollectSet() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCollectSet
 
GenericUDAFComputeStats - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFComputeStats
GenericUDAFComputeStats() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats
 
GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFBinaryStatsEvaluator.
GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator
 
GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator.BinaryStatsAgg - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator.BinaryStatsAgg() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator.BinaryStatsAgg
 
GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFBooleanStatsEvaluator.
GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator
 
GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator.BooleanStatsAgg - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator.BooleanStatsAgg() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator.BooleanStatsAgg
 
GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator
 
GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator.DecimalStatsAgg - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator.DecimalStatsAgg() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator.DecimalStatsAgg
 
GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFDoubleStatsEvaluator.
GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator
 
GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.DoubleStatsAgg - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.DoubleStatsAgg() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.DoubleStatsAgg
 
GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFLongStatsEvaluator.
GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator
 
GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.LongStatsAgg - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.LongStatsAgg() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.LongStatsAgg
 
GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFStringStatsEvaluator.
GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator
 
GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg
 
GenericUDAFContextNGrams - Class in org.apache.hadoop.hive.ql.udf.generic
Estimates the top-k contextual n-grams in arbitrary sequential data using a heuristic.
GenericUDAFContextNGrams() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams
 
GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
A constant-space heuristic to estimate the top-k contextual n-grams.
GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
GenericUDAFCorrelation - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the Pearson correlation coefficient corr(x, y), using the following stable one-pass method, based on: "Formulas for Robust, One-Pass Parallel Computation of Covariances and Arbitrary-Order Statistical Moments", Philippe Pebay, Sandia Labs and "The Art of Computer Programming, volume 2: Seminumerical Algorithms", Donald Knuth.
GenericUDAFCorrelation() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation
 
GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Evaluate the Pearson correlation coefficient using a stable one-pass algorithm, based on work by Philippe Pébay and Donald Knuth.
GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
GenericUDAFCount - Class in org.apache.hadoop.hive.ql.udf.generic
This class implements the COUNT aggregation function as in SQL.
GenericUDAFCount() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount
 
GenericUDAFCount.GenericUDAFCountEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFCountEvaluator.
GenericUDAFCount.GenericUDAFCountEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
GenericUDAFCovariance - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the covariance covar_pop(x, y), using the following one-pass method (ref.
GenericUDAFCovariance() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance
 
GenericUDAFCovariance.GenericUDAFCovarianceEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Evaluate the variance using the algorithm described in http://en.wikipedia.org/wiki/Algorithms_for_calculating_variance, presumably by Pébay, Philippe (2008), in "Formulas for Robust, One-Pass Parallel Computation of Covariances and Arbitrary-Order Statistical Moments", Technical Report SAND2008-6212, Sandia National Laboratories, http://infoserve.sandia.gov/sand_doc/2008/086212.pdf Incremental: n : mx_n = mx_(n-1) + [x_n - mx_(n-1)]/n : my_n = my_(n-1) + [y_n - my_(n-1)]/n : c_n = c_(n-1) + (x_n - mx_(n-1))*(y_n - my_n) : Merge: c_X = c_A + c_B + (mx_A - mx_B)*(my_A - my_B)*n_A*n_B/n_X This one-pass algorithm is stable.
GenericUDAFCovariance.GenericUDAFCovarianceEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
GenericUDAFCovarianceSample - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the sample covariance by extending GenericUDAFCovariance and overriding the terminate() method of the evaluator.
GenericUDAFCovarianceSample() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovarianceSample
 
GenericUDAFCovarianceSample.GenericUDAFCovarianceSampleEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the sample covariance by extending GenericUDAFCovarianceEvaluator and overriding the terminate() method of the evaluator.
GenericUDAFCovarianceSample.GenericUDAFCovarianceSampleEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovarianceSample.GenericUDAFCovarianceSampleEvaluator
 
GenericUDAFCumeDist - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFCumeDist() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCumeDist
 
GenericUDAFCumeDist.GenericUDAFCumeDistEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFCumeDist.GenericUDAFCumeDistEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCumeDist.GenericUDAFCumeDistEvaluator
 
GenericUDAFDenseRank - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFDenseRank() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFDenseRank
 
GenericUDAFDenseRank.GenericUDAFDenseRankEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFDenseRank.GenericUDAFDenseRankEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFDenseRank.GenericUDAFDenseRankEvaluator
 
GenericUDAFEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
A Generic User-defined aggregation function (GenericUDAF) for the use with Hive.
GenericUDAFEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
The constructor.
GenericUDAFEvaluator.AbstractAggregationBuffer - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFEvaluator.AbstractAggregationBuffer() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator.AbstractAggregationBuffer
 
GenericUDAFEvaluator.AggregationBuffer - Interface in org.apache.hadoop.hive.ql.udf.generic
Deprecated. use GenericUDAFEvaluator.AbstractAggregationBuffer instead
GenericUDAFEvaluator.AggregationType - Annotation Type in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFEvaluator.Mode - Enum in org.apache.hadoop.hive.ql.udf.generic
Mode.
GenericUDAFEWAHBitmap - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFEWAHBitmap.
GenericUDAFEWAHBitmap() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEWAHBitmap
 
GenericUDAFEWAHBitmap.GenericUDAFEWAHBitmapEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFEWAHBitmap.GenericUDAFEWAHBitmapEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEWAHBitmap.GenericUDAFEWAHBitmapEvaluator
 
GenericUDAFFirstValue - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFFirstValue() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFFirstValue
 
GenericUDAFFirstValue.GenericUDAFFirstValueEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFFirstValue.GenericUDAFFirstValueEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFFirstValue.GenericUDAFFirstValueEvaluator
 
GenericUDAFHistogramNumeric - Class in org.apache.hadoop.hive.ql.udf.generic
Computes an approximate histogram of a numerical column using a user-specified number of bins.
GenericUDAFHistogramNumeric() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric
 
GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Construct a histogram using an algorithm described by Ben-Haim and Tom-Tov.
GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
GenericUDAFLag - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFLag() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLag
 
GenericUDAFLag.GenericUDAFLagEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFLag.GenericUDAFLagEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLag.GenericUDAFLagEvaluator
 
GenericUDAFLastValue - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFLastValue() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLastValue
 
GenericUDAFLastValue.GenericUDAFLastValueEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFLastValue.GenericUDAFLastValueEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLastValue.GenericUDAFLastValueEvaluator
 
GenericUDAFLead - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFLead() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLead
 
GenericUDAFLead.GenericUDAFLeadEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFLead.GenericUDAFLeadEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLead.GenericUDAFLeadEvaluator
 
GenericUDAFLeadLag - Class in org.apache.hadoop.hive.ql.udf.generic
abstract class for Lead & lag UDAFs GenericUDAFLeadLag.
GenericUDAFLeadLag() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag
 
GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator
 
GenericUDAFMax - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFMax() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax
 
GenericUDAFMax.GenericUDAFMaxEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFMax.GenericUDAFMaxEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
GenericUDAFMin - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFMin() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin
 
GenericUDAFMin.GenericUDAFMinEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFMin.GenericUDAFMinEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
GenericUDAFMkCollectionEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFMkCollectionEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMkCollectionEvaluator
 
GenericUDAFMkCollectionEvaluator(GenericUDAFMkCollectionEvaluator.BufferType) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMkCollectionEvaluator
 
GenericUDAFnGrams - Class in org.apache.hadoop.hive.ql.udf.generic
Estimates the top-k n-grams in arbitrary sequential data using a heuristic.
GenericUDAFnGrams() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams
 
GenericUDAFnGrams.GenericUDAFnGramEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
A constant-space heuristic to estimate the top-k n-grams.
GenericUDAFnGrams.GenericUDAFnGramEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
GenericUDAFNTile - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFNTile() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFNTile
 
GenericUDAFNTile.GenericUDAFNTileEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFNTile.GenericUDAFNTileEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFNTile.GenericUDAFNTileEvaluator
 
GenericUDAFParameterInfo - Interface in org.apache.hadoop.hive.ql.udf.generic
A callback interface used in conjunction with GenericUDAFResolver2 interface that allows for a more extensible and flexible means of discovering the parameter types provided for UDAF invocation.
GenericUDAFPercentileApprox - Class in org.apache.hadoop.hive.ql.udf.generic
Computes an approximate percentile (quantile) from an approximate histogram, for very large numbers of rows where the regular percentile() UDAF might run out of memory.
GenericUDAFPercentileApprox() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox
 
GenericUDAFPercentileApprox.GenericUDAFMultiplePercentileApproxEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFPercentileApprox.GenericUDAFMultiplePercentileApproxEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFMultiplePercentileApproxEvaluator
 
GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Construct a histogram using the algorithm described by Ben-Haim and Tom-Tov, and then use it to compute an approximate percentile value.
GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
GenericUDAFPercentileApprox.GenericUDAFSinglePercentileApproxEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFPercentileApprox.GenericUDAFSinglePercentileApproxEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFSinglePercentileApproxEvaluator
 
GenericUDAFPercentRank - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFPercentRank() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentRank
 
GenericUDAFPercentRank.GenericUDAFPercentRankEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFPercentRank.GenericUDAFPercentRankEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentRank.GenericUDAFPercentRankEvaluator
 
GenericUDAFRank - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFRank() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank
 
GenericUDAFRank.GenericUDAFRankEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFRank.GenericUDAFRankEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank.GenericUDAFRankEvaluator
 
GenericUDAFResolver - Interface in org.apache.hadoop.hive.ql.udf.generic
Deprecated. Use GenericUDAFResolver2 instead.
GenericUDAFResolver2 - Interface in org.apache.hadoop.hive.ql.udf.generic
This interface extends the GenericUDAFResolver interface and provides more flexibility in terms of discovering the parameter types supplied to the UDAF.
GenericUDAFRowNumber - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFRowNumber() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRowNumber
 
GenericUDAFRowNumber.GenericUDAFRowNumberEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFRowNumber.GenericUDAFRowNumberEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRowNumber.GenericUDAFRowNumberEvaluator
 
GenericUDAFStd - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the standard deviation by extending GenericUDAFVariance and overriding the terminate() method of the evaluator.
GenericUDAFStd() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStd
 
GenericUDAFStd.GenericUDAFStdEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the standard deviation by extending GenericUDAFVarianceEvaluator and overriding the terminate() method of the evaluator.
GenericUDAFStd.GenericUDAFStdEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStd.GenericUDAFStdEvaluator
 
GenericUDAFStdSample - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the sample standard deviation by extending GenericUDAFVariance and overriding the terminate() method of the evaluator.
GenericUDAFStdSample() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStdSample
 
GenericUDAFStdSample.GenericUDAFStdSampleEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the sample standard deviation by extending GenericUDAFVarianceEvaluator and overriding the terminate() method of the evaluator.
GenericUDAFStdSample.GenericUDAFStdSampleEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStdSample.GenericUDAFStdSampleEvaluator
 
GenericUDAFSum - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFSum.
GenericUDAFSum() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum
 
GenericUDAFSum.GenericUDAFSumDouble - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFSumDouble.
GenericUDAFSum.GenericUDAFSumDouble() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumDouble
 
GenericUDAFSum.GenericUDAFSumHiveDecimal - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFSumHiveDecimal.
GenericUDAFSum.GenericUDAFSumHiveDecimal() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumHiveDecimal
 
GenericUDAFSum.GenericUDAFSumLong - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFSumLong.
GenericUDAFSum.GenericUDAFSumLong() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumLong
 
GenericUDAFVariance - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the variance.
GenericUDAFVariance() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance
 
GenericUDAFVariance.GenericUDAFVarianceEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Evaluate the variance using the algorithm described by Chan, Golub, and LeVeque in "Algorithms for computing the sample variance: analysis and recommendations" The American Statistician, 37 (1983) pp.
GenericUDAFVariance.GenericUDAFVarianceEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance.GenericUDAFVarianceEvaluator
 
GenericUDAFVarianceSample - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the sample variance by extending GenericUDAFVariance and overriding the terminate() method of the evaluator.
GenericUDAFVarianceSample() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVarianceSample
 
GenericUDAFVarianceSample.GenericUDAFVarianceSampleEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the sample variance by extending GenericUDAFVarianceEvaluator and overriding the terminate() method of the evaluator.
GenericUDAFVarianceSample.GenericUDAFVarianceSampleEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVarianceSample.GenericUDAFVarianceSampleEvaluator
 
GenericUDF - Class in org.apache.hadoop.hive.ql.udf.generic
A Generic User-defined function (GenericUDF) for the use with Hive.
GenericUDF() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
The constructor.
GenericUDF.DeferredJavaObject - Class in org.apache.hadoop.hive.ql.udf.generic
A basic dummy implementation of DeferredObject which just stores a Java Object reference.
GenericUDF.DeferredJavaObject(Object) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDF.DeferredJavaObject
 
GenericUDF.DeferredObject - Interface in org.apache.hadoop.hive.ql.udf.generic
A Defered Object allows us to do lazy-evaluation and short-circuiting.
GenericUDFAbs - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFAbs.
GenericUDFAbs() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFAbs
 
GenericUDFArray - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFArray.
GenericUDFArray() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFArray
 
GenericUDFArrayContains - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFArrayContains.
GenericUDFArrayContains() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFArrayContains
 
GenericUDFAssertTrue - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFAssertTrue
GenericUDFAssertTrue() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFAssertTrue
 
GenericUDFBaseCompare - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Base Class for operations.
GenericUDFBaseCompare() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
GenericUDFBaseCompare.CompareType - Enum in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFBaseNumeric - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Base Class for operations.
GenericUDFBaseNumeric() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
GenericUDFBasePad - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFBasePad(String) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBasePad
 
GenericUDFBaseTrim - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFBaseTrim(String) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseTrim
 
GenericUDFBaseUnary - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFBaseUnary() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
GenericUDFBetween - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFBetween() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBetween
 
GenericUDFBridge - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFBridge encapsulates UDF to provide the same interface as GenericUDF.
GenericUDFBridge(String, boolean, String) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
Create a new GenericUDFBridge object.
GenericUDFBridge() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
GenericUDFCase - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for SQL construct "CASE a WHEN b THEN c [ELSE f] END".
GenericUDFCase() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCase
 
GenericUDFCeil - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFCeil() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCeil
 
GenericUDFCoalesce - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for SQL construct "COALESCE(a, b, c)".
GenericUDFCoalesce() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCoalesce
 
GenericUDFConcat - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFConcat.
GenericUDFConcat() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcat
 
GenericUDFConcatWS - Class in org.apache.hadoop.hive.ql.udf.generic
Generic UDF for string function CONCAT_WS(sep, [string | array(string)]+).
GenericUDFConcatWS() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcatWS
 
GenericUDFDate - Class in org.apache.hadoop.hive.ql.udf.generic
UDFDate.
GenericUDFDate() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDate
 
GenericUDFDateAdd - Class in org.apache.hadoop.hive.ql.udf.generic
UDFDateAdd.
GenericUDFDateAdd() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateAdd
 
GenericUDFDateDiff - Class in org.apache.hadoop.hive.ql.udf.generic
UDFDateDiff.
GenericUDFDateDiff() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateDiff
 
GenericUDFDateSub - Class in org.apache.hadoop.hive.ql.udf.generic
UDFDateSub.
GenericUDFDateSub() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateSub
 
GenericUDFDecode - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFDecode() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDecode
 
GenericUDFElt - Class in org.apache.hadoop.hive.ql.udf.generic
Generic UDF for string function ELT(N,str1,str2,str3,...).
GenericUDFElt() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFElt
 
GenericUDFEncode - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFEncode() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFEncode
 
GenericUDFEWAHBitmapAnd - Class in org.apache.hadoop.hive.ql.udf.generic
GenericEWAHUDFBitmapAnd.
GenericUDFEWAHBitmapAnd() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFEWAHBitmapAnd
 
GenericUDFEWAHBitmapEmpty - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFEWAHBitmapEmpty() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFEWAHBitmapEmpty
 
GenericUDFEWAHBitmapOr - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFEWAHBitmapOr.
GenericUDFEWAHBitmapOr() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFEWAHBitmapOr
 
GenericUDFField - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFField.
GenericUDFField() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFField
 
GenericUDFFloor - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFFloor() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFloor
 
GenericUDFFloorCeilBase - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFFloorCeilBase() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFloorCeilBase
 
GenericUDFFormatNumber - Class in org.apache.hadoop.hive.ql.udf.generic
Generic UDF for format_number function FORMAT_NUMBER(X, D).
GenericUDFFormatNumber() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFormatNumber
 
GenericUDFFromUtcTimestamp - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFFromUtcTimestamp() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFromUtcTimestamp
 
GenericUDFHash - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for computing hash values.
GenericUDFHash() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFHash
 
GenericUDFIf - Class in org.apache.hadoop.hive.ql.udf.generic
IF(expr1,expr2,expr3)
If expr1 is TRUE (expr1 <> 0 and expr1 <> NULL) then IF() returns expr2; otherwise it returns expr3.
GenericUDFIf() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIf
 
GenericUDFIn - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFIn Example usage: SELECT key FROM src WHERE key IN ("238", "1"); From MySQL page on IN(): To comply with the SQL standard, IN returns NULL not only if the expression on the left hand side is NULL, but also if no match is found in the list and one of the expressions in the list is NULL.
GenericUDFIn() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIn
 
GenericUDFIndex - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFIndex.
GenericUDFIndex() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIndex
 
GenericUDFInFile - Class in org.apache.hadoop.hive.ql.udf.generic
IN_FILE(str, filename) returns true if 'str' appears in the file specified by 'filename'.
GenericUDFInFile() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFInFile
 
GenericUDFInstr - Class in org.apache.hadoop.hive.ql.udf.generic
Generic UDF for string function INSTR(str,substr).
GenericUDFInstr() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFInstr
 
GenericUDFLag - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFLag() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLag
 
GenericUDFLead - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFLead() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLead
 
GenericUDFLeadLag - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFLeadLag() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
GenericUDFLocate - Class in org.apache.hadoop.hive.ql.udf.generic
Generic UDF for string function LOCATE(substr, str), LOCATE(substr, str, start).
GenericUDFLocate() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLocate
 
GenericUDFLower - Class in org.apache.hadoop.hive.ql.udf.generic
UDFLower.
GenericUDFLower() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLower
 
GenericUDFLpad - Class in org.apache.hadoop.hive.ql.udf.generic
UDFLpad.
GenericUDFLpad() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLpad
 
GenericUDFLTrim - Class in org.apache.hadoop.hive.ql.udf.generic
UDFLTrim.
GenericUDFLTrim() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLTrim
 
GenericUDFMacro - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFMacro wraps a user-defined macro expression into a GenericUDF interface.
GenericUDFMacro(String, ExprNodeDesc, List<String>, List<TypeInfo>) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
GenericUDFMacro() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
GenericUDFMap - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFMap.
GenericUDFMap() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMap
 
GenericUDFMapKeys - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFMapKeys.
GenericUDFMapKeys() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMapKeys
 
GenericUDFMapValues - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFMapValues.
GenericUDFMapValues() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMapValues
 
GenericUDFNamedStruct - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFNamedStruct() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFNamedStruct
 
GenericUDFNvl - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFNvl() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFNvl
 
GenericUDFOPAnd - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for computing and.
GenericUDFOPAnd() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPAnd
 
GenericUDFOPDivide - Class in org.apache.hadoop.hive.ql.udf.generic
Note that in SQL, the return type of divide is not necessarily the same as the parameters.
GenericUDFOPDivide() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPDivide
 
GenericUDFOPEqual - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for operation EQUAL.
GenericUDFOPEqual() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqual
 
GenericUDFOPEqualNS - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFOPEqualNS() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualNS
 
GenericUDFOPEqualOrGreaterThan - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for operation EqualOrGreaterThan.
GenericUDFOPEqualOrGreaterThan() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualOrGreaterThan
 
GenericUDFOPEqualOrLessThan - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for operation EqualOrLessThan.
GenericUDFOPEqualOrLessThan() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualOrLessThan
 
GenericUDFOPGreaterThan - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for operation GreaterThan.
GenericUDFOPGreaterThan() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPGreaterThan
 
GenericUDFOPLessThan - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for operation LessThan.
GenericUDFOPLessThan() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPLessThan
 
GenericUDFOPMinus - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFOPMinus() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMinus
 
GenericUDFOPMod - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFOPMod() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMod
 
GenericUDFOPMultiply - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFOPMultiply() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPMultiply
 
GenericUDFOPNegative - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFOPNegative() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNegative
 
GenericUDFOPNot - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFOPNot.
GenericUDFOPNot() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNot
 
GenericUDFOPNotEqual - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for operation Not EQUAL.
GenericUDFOPNotEqual() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotEqual
 
GenericUDFOPNotNull - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFOPNotNull.
GenericUDFOPNotNull() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotNull
 
GenericUDFOPNull - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFOPNull.
GenericUDFOPNull() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNull
 
GenericUDFOPOr - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for computing or.
GenericUDFOPOr() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPOr
 
GenericUDFOPPlus - Class in org.apache.hadoop.hive.ql.udf.generic
The reason that we list evaluate methods with all numeric types is for both better performance and type checking (so we know int + int is still an int instead of a double); otherwise a single method that takes (Number a, Number b) and use a.doubleValue() == b.doubleValue() is enough.
GenericUDFOPPlus() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPPlus
 
GenericUDFOPPositive - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFOPPositive() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPPositive
 
GenericUDFPosMod - Class in org.apache.hadoop.hive.ql.udf.generic
class for computing positive modulo.
GenericUDFPosMod() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPosMod
 
GenericUDFPower - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFPower() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPower
 
GenericUDFPrintf - Class in org.apache.hadoop.hive.ql.udf.generic
Generic UDF for printf function printf(String format, Obj...
GenericUDFPrintf() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPrintf
 
GenericUDFReflect - Class in org.apache.hadoop.hive.ql.udf.generic
A simple generic udf to call java static functions via reflection.
GenericUDFReflect() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFReflect
 
GenericUDFReflect2 - Class in org.apache.hadoop.hive.ql.udf.generic
A simple generic udf to call java functions via reflection.
GenericUDFReflect2() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFReflect2
 
GenericUDFRound - Class in org.apache.hadoop.hive.ql.udf.generic
Note: rounding function permits rounding off integer digits in decimal numbers, which essentially downgrades the scale to negative territory.
GenericUDFRound() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFRound
 
GenericUDFRpad - Class in org.apache.hadoop.hive.ql.udf.generic
UDFRpad.
GenericUDFRpad() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFRpad
 
GenericUDFRTrim - Class in org.apache.hadoop.hive.ql.udf.generic
UDFRTrim.
GenericUDFRTrim() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFRTrim
 
GenericUDFSentences - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFSentences: splits a natural language chunk of text into sentences and words.
GenericUDFSentences() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSentences
 
GenericUDFSize - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFSize.
GenericUDFSize() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSize
 
GenericUDFSortArray - Class in org.apache.hadoop.hive.ql.udf.generic
Generic UDF for array sort SORT_ARRAY(array(obj1, obj2, obj3...)).
GenericUDFSortArray() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSortArray
 
GenericUDFSplit - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFSplit.
GenericUDFSplit() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSplit
 
GenericUDFStringToMap - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFStringToMap.
GenericUDFStringToMap() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStringToMap
 
GenericUDFStruct - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFStruct() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStruct
 
GenericUDFTimestamp - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFTimestamp Example usage: ...
GenericUDFTimestamp() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTimestamp
 
GenericUDFToBinary - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFToBinary() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToBinary
 
GenericUDFToChar - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFToChar() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToChar
 
GenericUDFToDate - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFToDate
GenericUDFToDate() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToDate
 
GenericUDFToDecimal - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFToDecimal() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToDecimal
 
GenericUDFToUnixTimeStamp - Class in org.apache.hadoop.hive.ql.udf.generic
deterministic version of UDFUnixTimeStamp.
GenericUDFToUnixTimeStamp() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToUnixTimeStamp
 
GenericUDFToUtcTimestamp - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFToUtcTimestamp() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToUtcTimestamp
 
GenericUDFToVarchar - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFToVarchar() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToVarchar
 
GenericUDFTranslate - Class in org.apache.hadoop.hive.ql.udf.generic
TRANSLATE(string input, string from, string to) is an equivalent function to translate in PostGresSQL.
GenericUDFTranslate() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTranslate
 
GenericUDFTrim - Class in org.apache.hadoop.hive.ql.udf.generic
UDFTrim.
GenericUDFTrim() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTrim
 
GenericUDFUnion - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFUnion() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUnion
 
GenericUDFUnixTimeStamp - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFUnixTimeStamp() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUnixTimeStamp
 
GenericUDFUpper - Class in org.apache.hadoop.hive.ql.udf.generic
UDFUpper.
GenericUDFUpper() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUpper
 
GenericUDFUtils - Class in org.apache.hadoop.hive.ql.udf.generic
Util functions for GenericUDF classes.
GenericUDFUtils.ConversionHelper - Class in org.apache.hadoop.hive.ql.udf.generic
Convert parameters for the method if needed.
GenericUDFUtils.ConversionHelper(Method, ObjectInspector[]) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ConversionHelper
Create a PrimitiveConversionHelper for Method m.
GenericUDFUtils.ReturnObjectInspectorResolver - Class in org.apache.hadoop.hive.ql.udf.generic
This class helps to find the return ObjectInspector for a GenericUDF.
GenericUDFUtils.ReturnObjectInspectorResolver() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ReturnObjectInspectorResolver
 
GenericUDFUtils.ReturnObjectInspectorResolver(boolean) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ReturnObjectInspectorResolver
 
GenericUDFUtils.StringHelper - Class in org.apache.hadoop.hive.ql.udf.generic
Helper class for UDFs returning string/varchar/char
GenericUDFUtils.StringHelper(PrimitiveObjectInspector.PrimitiveCategory) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.StringHelper
 
GenericUDFWhen - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for SQL construct "CASE WHEN a THEN b WHEN c THEN d [ELSE f] END".
GenericUDFWhen() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFWhen
 
GenericUDFXPath - Class in org.apache.hadoop.hive.ql.udf.xml
 
GenericUDFXPath() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.GenericUDFXPath
 
GenericUDTF - Class in org.apache.hadoop.hive.ql.udf.generic
A Generic User-defined Table Generating Function (UDTF) Generates a variable number of output rows for a single input row.
GenericUDTF() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDTF
 
GenericUDTFExplode - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDTFExplode.
GenericUDTFExplode() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFExplode
 
GenericUDTFInline - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDTFInline() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFInline
 
GenericUDTFJSONTuple - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDTFJSONTuple: this
GenericUDTFJSONTuple() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFJSONTuple
 
GenericUDTFParseUrlTuple - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDTFParseUrlTuple: this
GenericUDTFParseUrlTuple() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFParseUrlTuple
 
GenericUDTFPosExplode - Class in org.apache.hadoop.hive.ql.udf.generic
PosExplode.
GenericUDTFPosExplode() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFPosExplode
 
GenericUDTFStack - Class in org.apache.hadoop.hive.ql.udf.generic
Takes a row of size k of data and splits it into n rows of data.
GenericUDTFStack() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFStack
 
genExprNode(ASTNode, TypeCheckCtx) - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
 
genExprNodeDesc(ASTNode, RowResolver) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
Generates an expression node descriptor for the expression with TypeCheckCtx.
genExprNodeDesc(ASTNode, RowResolver, TypeCheckCtx) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
Returns expression node descriptor for the expression.
genLocalWorkForMapJoin(MapredWork, MapJoinOperator, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
genMapJoinOpAndLocalWork(HiveConf, MapredWork, JoinOperator, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
Convert the join to a map-join and also generate any local work needed.
GenMapRedUtils - Class in org.apache.hadoop.hive.ql.optimizer
General utility common functions for the Processor to convert operator into map-reduce tasks.
GenMapRedWalker - Class in org.apache.hadoop.hive.ql.parse
Walks the operator tree in pre order fashion.
GenMapRedWalker(Dispatcher) - Constructor for class org.apache.hadoop.hive.ql.parse.GenMapRedWalker
constructor of the walker - the dispatcher is passed.
GenMRFileSink1 - Class in org.apache.hadoop.hive.ql.optimizer
Processor for the rule - table scan followed by reduce sink.
GenMRFileSink1() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRFileSink1
 
GenMROperator - Class in org.apache.hadoop.hive.ql.optimizer
Processor for the rule - no specific rule fired.
GenMROperator() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMROperator
 
GenMRProcContext - Class in org.apache.hadoop.hive.ql.optimizer
Processor Context for creating map reduce task.
GenMRProcContext() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
GenMRProcContext(HiveConf, HashMap<Operator<? extends OperatorDesc>, Task<? extends Serializable>>, ParseContext, List<Task<MoveWork>>, List<Task<? extends Serializable>>, LinkedHashMap<Operator<? extends OperatorDesc>, GenMRProcContext.GenMapRedCtx>, Set<ReadEntity>, Set<WriteEntity>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
GenMRProcContext.GenMapRedCtx - Class in org.apache.hadoop.hive.ql.optimizer
GenMapRedCtx is used to keep track of the current state.
GenMRProcContext.GenMapRedCtx() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMapRedCtx
 
GenMRProcContext.GenMapRedCtx(Task<? extends Serializable>, String) - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMapRedCtx
 
GenMRProcContext.GenMRUnionCtx - Class in org.apache.hadoop.hive.ql.optimizer
GenMRUnionCtx.
GenMRProcContext.GenMRUnionCtx(Task<? extends Serializable>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
GenMRRedSink1 - Class in org.apache.hadoop.hive.ql.optimizer
Processor for the rule - table scan followed by reduce sink.
GenMRRedSink1() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRRedSink1
 
GenMRRedSink2 - Class in org.apache.hadoop.hive.ql.optimizer
Processor for the rule - reduce sink followed by reduce sink.
GenMRRedSink2() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRRedSink2
 
GenMRRedSink3 - Class in org.apache.hadoop.hive.ql.optimizer
Processor for the rule - union followed by reduce sink.
GenMRRedSink3() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRRedSink3
 
GenMRSkewJoinProcessor - Class in org.apache.hadoop.hive.ql.optimizer.physical
GenMRSkewJoinProcessor.
GenMRTableScan1 - Class in org.apache.hadoop.hive.ql.optimizer
Processor for the rule - table scan.
GenMRTableScan1() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRTableScan1
 
GenMRUnion1 - Class in org.apache.hadoop.hive.ql.optimizer
Processor for the rule - TableScan followed by Union.
GenMRUnion1() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRUnion1
 
genPlan(QB) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
genPruner(String, ExprNodeDesc, Partition) - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBExprProcFactory
Generates the list bucketing pruner for the expression tree.
genPruner(String, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory
Generates the partition pruner for the expression tree.
genRootTableScan(Operator<? extends OperatorDesc>, List<String>) - Static method in class org.apache.hadoop.hive.ql.parse.TableAccessAnalyzer
This method traces up from the given operator to the root of the operator graph until a TableScanOperator is reached.
GenTezProcContext - Class in org.apache.hadoop.hive.ql.parse
GenTezProcContext.
GenTezProcContext(HiveConf, ParseContext, List<Task<MoveWork>>, List<Task<? extends Serializable>>, Set<ReadEntity>, Set<WriteEntity>) - Constructor for class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
GenTezUtils - Class in org.apache.hadoop.hive.ql.parse
GenTezUtils is a collection of shared helper methods to produce TezWork
GenTezWork - Class in org.apache.hadoop.hive.ql.parse
GenTezWork separates the operator tree into tez tasks.
GenTezWork(GenTezUtils) - Constructor for class org.apache.hadoop.hive.ql.parse.GenTezWork
Constructor takes utils as parameter to facilitate testing
GenTezWorkWalker - Class in org.apache.hadoop.hive.ql.parse
Walks the operator tree in DFS fashion.
GenTezWorkWalker(Dispatcher, GenTezProcContext) - Constructor for class org.apache.hadoop.hive.ql.parse.GenTezWorkWalker
constructor of the walker - the dispatcher is passed.
genVectorExpressionWritable(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory
Compiles the appropriate vector expression writer based on an expression info (ExprNodeDesc)
genVectorExpressionWritable(ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory
Compiles the appropriate vector expression writer based on an expression info (ExprNodeDesc)
get(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluatorFactory
 
get() - Static method in class org.apache.hadoop.hive.ql.exec.MapredContext
 
get(Class<T>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
 
get(Class<T>, RowSchema) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
 
get(T, Operator<? extends OperatorDesc>...) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
Returns an operator given the conf and a list of children operators.
get(T, RowSchema, Operator...) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
Returns an operator given the conf and a list of children operators.
get(MapJoinKey) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
get(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
get(MapJoinKey) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer
 
get(Class<T>, HiveConf) - Static method in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
get(T, HiveConf, Task<? extends Serializable>...) - Static method in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
get() - Static method in class org.apache.hadoop.hive.ql.io.IOContext
 
get() - Static method in class org.apache.hadoop.hive.ql.io.IOPrepareCache
 
get(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetByteInspector
 
get(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetShortInspector
 
get(HiveConf) - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
Gets hive object for the current thread.
get(HiveConf, boolean) - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
get a connection to metastore.
get() - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
 
get(ASTNode) - Static method in enum org.apache.hadoop.hive.ql.parse.QBSubQuery.SubQueryType
 
get(String, String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
Gets the column Info to tab_alias.col_alias type of a column reference.
get(HiveConf, ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzerFactory
 
get(LeadLagInfo, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.parse.WindowingExprNodeEvaluatorFactory
 
get(String) - Static method in class org.apache.hadoop.hive.ql.processors.CommandProcessorFactory
 
get(String[], HiveConf) - Static method in class org.apache.hadoop.hive.ql.processors.CommandProcessorFactory
 
get() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
get the current session.
get() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF.DeferredJavaObject
 
get() - Method in interface org.apache.hadoop.hive.ql.udf.generic.GenericUDF.DeferredObject
 
get() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ReturnObjectInspectorResolver
Returns the ObjectInspector of the return value.
get(int) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.SameList
 
get() - Static method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
get_privilege_set(HiveObjectType, String, String, List<String>, String, String, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
GET_SPLITS - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
getAbsolutePath(String) - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator.PathFinder
Returns the full path name of this file if it is listed in the path.
getAcidState(Path, Configuration, ValidTxnList) - Static method in class org.apache.hadoop.hive.ql.io.AcidUtils
Get the ACID state of the given directory.
getAdditionalSemanticInputs() - Method in class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
getAddPartitionDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAfterCol() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getAggFuncCnt() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getAggFuncColList() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getAggFunction() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getAggKey() - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanWork
 
getAggKey() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
getAggregateFunction() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
getAggregateTraitSet(RelOptCluster, RelTraitSet, List<Integer>, List<AggregateCall>, RelNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.TraitsUtil
 
getAggregationBuffer(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferRow
returns the aggregation buffer for an aggregation expression, by index.
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorAggregateExpression
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFAvgDecimal
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCount
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCountStar
 
getAggregationBufferFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFSumDecimal
 
getAggregationBuffers() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferBatch
the array of aggregation buffers for the current batch.
getAggregationBuffers() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferRow
returns the array of aggregation buffers (the entire set).
getAggregationExprsForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getAggregatorExpression(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
getAggregators() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
getAggregators() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getAggregatorsFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferBatch
Returns the fixed size consumed by the aggregation buffers
getAggregatorStrings() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getAggrExprNode() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
getAlias() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
getAlias() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.TableAliasInfo
 
getAlias() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapInnerQuery
Return the assigned alias of the SELECT statement
getAlias() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapOuterQuery
 
getAlias() - Method in interface org.apache.hadoop.hive.ql.index.bitmap.BitmapQuery
 
getAlias() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
getAlias() - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
getAlias() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getAlias() - Method in class org.apache.hadoop.hive.ql.parse.QBSubQuery
 
getAlias() - Method in interface org.apache.hadoop.hive.ql.parse.SubQueryUtils.ISubQueryJoinInfo
 
getAlias() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowExpressionSpec
 
getAlias() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFInputDef
 
getAlias() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowExpressionDef
 
getAlias() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getAlias(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Returns the alias of the specified expr.
getAliasBucketBaseFileNameMapping() - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
getAliasBucketFileNameMapping() - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
getAliasBucketFileNameMapping() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getAliasBucketFiles(String, String, String) - Method in interface org.apache.hadoop.hive.ql.exec.BucketMatcher
 
getAliasBucketFiles(String, String, String) - Method in class org.apache.hadoop.hive.ql.exec.DefaultBucketMatcher
 
getAliases() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getAliases() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getAliasFilter() - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
getAliasFilter() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
getAliasFilter() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinRowContainer
 
getAliasToFetchWork() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getAliasToKnownSize() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
getAliasToLateralViews() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getAliasToOpInfo() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getAliasToPartnInfo() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getAliasToSink() - Method in class org.apache.hadoop.hive.ql.plan.SMBJoinDesc
 
getAliasToTable() - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getAliasToWdwExpr() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec
 
getAliasToWork() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getAliasToWork() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getAllCols() - Method in class org.apache.hadoop.hive.ql.metadata.Table
Returns a list of all the columns of the table (data columns + partition columns in that order.
getAllColumnsInformation(List<FieldSchema>, boolean, boolean) - Static method in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatUtils
Write formatted information about the given columns to a string
getAllColumnsInformation(List<FieldSchema>, List<FieldSchema>, boolean, boolean, boolean) - Static method in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatUtils
Write formatted information about the given columns, including partition columns to a string
getAllColumnsInformation(Index) - Static method in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatUtils
 
getAllColumnsInformation(List<FieldSchema>, List<FieldSchema>, int) - Static method in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataPrettyFormatUtils
 
getAllDatabases() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get all existing database names.
getAllExprToColumnAlias() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getAllIndexes(short) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getAllOperators() - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
getAllOperators() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
getAllowStatefulFunctions() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getAllPartitionsOf(Table) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get all the partitions; unlike Hive.getPartitions(Table), does not include auth.
getAllReduceSinkOperators() - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.IntraQueryCorrelation
 
getAllRoleNames() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get all existing role names.
getAllRoles() - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessController
 
getAllRoles() - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
 
getAllRoles() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
getAllRoles() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
getAllRootOperators() - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
getAllRootOperators() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getAllRootOperators() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getAllRootOperators() - Method in class org.apache.hadoop.hive.ql.plan.UnionWork
 
getAllStructFieldRefs() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
getAllTables() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get all table names for the current database.
getAllTables(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get all table names for the specified database.
getAllWindowingSpecs() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getAllWork() - Method in class org.apache.hadoop.hive.ql.plan.TezWork
getAllWork returns a topologically sorted list of BaseWork
getAllWorkUnsorted() - Method in class org.apache.hadoop.hive.ql.plan.TezWork
 
getAlterDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAlterIndexDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAlternateMappings(String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getAlterTableAlterPartDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAlterTableExchangePartition() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAlterTableTypeString() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getAlterTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAlterTblSimpleDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAlterType() - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
getAmt() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.BoundarySpec
 
getAmt() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.CurrentRowSpec
 
getAmt() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.RangeBoundarySpec
 
getAmt() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.ValueBoundarySpec
 
getAmt() - Method in class org.apache.hadoop.hive.ql.plan.ptf.BoundaryDef
 
getAmt() - Method in class org.apache.hadoop.hive.ql.plan.ptf.CurrentRowDef
 
getAmt() - Method in class org.apache.hadoop.hive.ql.plan.ptf.RangeBoundaryDef
 
getAmt() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ValueBoundaryDef
 
getAmt() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator
 
getAmt() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
getAndExprStats() - Method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.AnnotateStatsProcCtx
 
getAndIncrementId() - Static method in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
getAndInitBackupTask() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getAndMakeChild(T, Operator...) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
Returns an operator given the conf and a list of parent operators.
getAndMakeChild(T, List<Operator<? extends OperatorDesc>>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
Returns an operator given the conf and a list of parent operators.
getAndMakeChild(T, RowSchema, Operator...) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
Returns an operator given the conf and a list of parent operators.
getAndMakeChild(T, RowSchema, Map<String, ExprNodeDesc>, Operator...) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
Returns an operator given the conf and a list of parent operators.
getAndMakeChild(T, RowSchema, List<Operator<? extends OperatorDesc>>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
Returns an operator given the conf and a list of parent operators.
getAndMakeChild(T, RowSchema, Map<String, ExprNodeDesc>, List<Operator<? extends OperatorDesc>>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
Returns an operator given the conf and a list of parent operators.
getAndMakeChild(T, HiveConf, Task<? extends Serializable>...) - Static method in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
getAnyKey() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
getAnyKey() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer
 
getAppendedAliasFromId(String, String) - Static method in class org.apache.hadoop.hive.ql.parse.QB
 
getAppJarLr() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
getArchivingLevel(Partition) - Static method in class org.apache.hadoop.hive.ql.exec.ArchiveUtils
Returns archiving level, which is how many fields were set in partial specification ARCHIVE was run for
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringColumn
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringScalar
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringColumn
 
getArg1Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringScalar
 
getArg2Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringColumn
 
getArg2Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringScalar
 
getArg2Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringColumn
 
getArg2Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringScalar
 
getArg3Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringColumn
 
getArg3Column() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringColumn
 
getArg3Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringScalar
 
getArg3Scalar() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringScalar
 
getArgDescs() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
getArgs() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
getArgs() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFunctionSpec
 
getArgs() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
getArgs() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
getArgTypeList() - Method in exception org.apache.hadoop.hive.ql.exec.UDFArgumentException
 
getArgumentId() - Method in exception org.apache.hadoop.hive.ql.exec.UDFArgumentTypeException
 
getAst() - Method in class org.apache.hadoop.hive.ql.parse.QBSubQuery.SubQueryTypeDef
 
getAstNode() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFInputSpec
 
getASTNode(ColumnInfo, RowResolver) - Static method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
getAstStringTree() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
getAt(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer
 
getAt(int) - Method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
getAuthenticator(Configuration, HiveConf.ConfVars) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
getAuthenticator() - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
 
getAuthenticator() - Method in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
getAuthenticator() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getAuthorizationMode() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getAuthorizationProvider() - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
getAuthorizationProvider() - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
Returns the implementation specific authorization provider
getAuthorizeProviderManager(Configuration, HiveConf.ConfVars, HiveAuthenticationProvider) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
getAuthorizeProviderManager(Configuration, HiveConf.ConfVars, HiveAuthenticationProvider, boolean) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
Create a new instance of HiveAuthorizationProvider
getAuthorizer() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getAuthorizerFactory(Configuration, HiveConf.ConfVars) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
Return HiveAuthorizerFactory used by new authorization plugin interface.
getAuthorizerV2() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getAvgColLen() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
getAvgColLenOfFixedLengthTypes(String) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get size of fixed length primitives
getAvgColLenOfVariableLengthTypes(HiveConf, ObjectInspector, String) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get the raw data size of variable length data types
getAvgRowSize() - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
getBackupChildrenTasks() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getBackupTask() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getBase() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLogWithBaseDoubleToDouble
 
getBase() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLogWithBaseLongToDouble
 
getBaseBigAlias() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
getBaseCols() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
getBaseDirectory() - Method in interface org.apache.hadoop.hive.ql.io.AcidUtils.Directory
Get the base directory.
getBaseFileName() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getBaseName(LocalResource) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
getBaseSrc() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getBaseTableName() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getBaseTableName() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
getBaseTableName() - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
getBaseToIdxTableMap() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getBasicStat() - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Returns the basic type of the supported statistics.
getBasicStatForPartitions(Table, List<Partition>, String) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get basic stats of partitions
getBasicStatForTable(Table, String) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get basic stats of table
getBasicStatsState() - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
getBigDecimal() - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
getBigKeysDirMap() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getBigKeysDirMap() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getBigTableAlias() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getBigTableBucketNumMapping() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getBigTableCandidates(JoinCondDesc[]) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
Get a list of big table candidates.
getBigTablePartSpecToFileMapping() - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
getBigTablePartSpecToFileMapping() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getBigTablePosition(ParseContext, JoinOperator, Set<Integer>) - Method in class org.apache.hadoop.hive.ql.optimizer.AvgPartitionSizeBasedBigTableSelectorForAutoSMJ
 
getBigTablePosition(ParseContext, JoinOperator, Set<Integer>) - Method in interface org.apache.hadoop.hive.ql.optimizer.BigTableSelectorForAutoSMJ
 
getBigTablePosition(ParseContext, JoinOperator, Set<Integer>) - Method in class org.apache.hadoop.hive.ql.optimizer.LeftmostBigTableSelectorForAutoSMJ
 
getBigTablePosition() - Method in class org.apache.hadoop.hive.ql.optimizer.SortBucketJoinProcCtx
 
getBigTablePosition(ParseContext, JoinOperator, Set<Integer>) - Method in class org.apache.hadoop.hive.ql.optimizer.TableSizeBasedBigTableSelectorForAutoSMJ
 
getBigTblPartsToBucketFileNames() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
getBigTblPartsToBucketNumber() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
getBin(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Returns a particular histogram bin.
getBinary() - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BinaryWritable
 
getBitVector(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
getBitVectorSize() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
getBody() - Method in class org.apache.hadoop.hive.ql.plan.CreateMacroDesc
 
getBody() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
getBookkeepingInfo(String) - Method in class org.apache.hadoop.hive.ql.exec.Stat
 
getBoolean(String) - Static method in class org.apache.hadoop.hive.ql.processors.SetProcessor
 
getBoolExprProcessor() - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get BoolExprProcessor.
getBottomReduceSinkOperators() - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.IntraQueryCorrelation
 
getBucket() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
getBucket(K2, V2, int) - Method in class org.apache.hadoop.hive.ql.io.DefaultHivePartitioner
Use Object.hashCode() to partition.
getBucket(K2, V2, int) - Method in interface org.apache.hadoop.hive.ql.io.HivePartitioner
Get the final bucket within a partition.
getBucketColNames() - Method in class org.apache.hadoop.hive.ql.plan.OpTraits
 
getBucketCols() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getBucketCols() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getBucketCols() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
getBucketCols() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getBucketCols() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getBucketColumns() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getBucketCount() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getBucketedCols(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx
 
getBucketedColsByDirectory() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx
 
getBucketedColsByDirectory() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getBucketFileName(String) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getBucketFileNameMapping() - Method in interface org.apache.hadoop.hive.ql.exec.BucketMatcher
 
getBucketFileNameMapping() - Method in class org.apache.hadoop.hive.ql.exec.DefaultBucketMatcher
 
getBucketFileNameMapping() - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
getBucketFileNameMapping() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getBucketFilePathsOfPartition(Path, ParseContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.AbstractBucketJoinProc
 
getBucketGroup() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getBucketId() - Method in class org.apache.hadoop.hive.ql.io.RecordIdentifier
What was the original bucket id for the last row?
getBucketingDimensionId() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getBucketMapjoinContext() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getBucketMapjoinContext() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getBucketMapjoinContextExplain() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getBucketMatcherClass() - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
getBucketPath(int) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
mapping from bucket number to bucket path
getBufferSize() - Method in class org.apache.hadoop.hive.ql.plan.CollectDesc
 
getBufferType() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMkCollectionEvaluator
 
getByteLength(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
getBytes(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
getBytes() - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BinaryWritable
 
getByteStart(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
getBytesValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
getCache(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.ObjectCacheFactory
Returns the appropriate cache
getCandidateFilterOps() - Method in class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
getCanonicalErrorMsg() - Method in exception org.apache.hadoop.hive.ql.metadata.HiveException
 
getCategory() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
getCategory() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveArrayInspector
 
getCfg() - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
getCharTypeInfo(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.ParseUtils
 
getCheckFileFormat() - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
getChildErrStream() - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
getChildExpressions() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression
 
getChildIndexToOriginalNumParents() - Method in class org.apache.hadoop.hive.ql.plan.DemuxDesc
 
getChildOperators() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getChildOutStream() - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
getChildren() - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
Return child evaluators if exist
getChildren() - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeGenericFuncEvaluator
 
getChildren() - Method in class org.apache.hadoop.hive.ql.exec.Operator
Implements the getChildren function for the Node Interface.
getChildren() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getChildren() - Method in interface org.apache.hadoop.hive.ql.lib.Node
Gets the vector of children nodes.
getChildren() - Method in class org.apache.hadoop.hive.ql.parse.ASTNode
 
getChildren() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnListDesc
 
getChildren() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
getChildren() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
getChildren() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
getChildren(BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
getChildren returns all the nodes with edges leading out of work
getChildTasks() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getClassName() - Method in class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
getClauseNames() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getClauseNamesForDest() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getClientIp() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
getCloneTSOpMap() - Method in class org.apache.hadoop.hive.ql.optimizer.SkewJoinOptimizer.SkewJoinOptProcCtx
 
getClusterByForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
Get the Cluster By AST for the clause.
getClusterStatus() - Method in class org.apache.hadoop.hive.ql.Driver
Return the status information about the Map-Reduce cluster
getCmd() - Method in class org.apache.hadoop.hive.ql.Context
Find the original query command.
getCmd() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getCode() - Method in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
getCodec() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
getCol() - Method in class org.apache.hadoop.hive.ql.plan.ExtractDesc
 
getColList() - Method in class org.apache.hadoop.hive.ql.plan.SelectDesc
 
getColListString() - Method in class org.apache.hadoop.hive.ql.plan.SelectDesc
 
getCollItemDelim() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getCollItemDelim() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getColName() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getColName() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
getColNames() - Method in class org.apache.hadoop.hive.ql.plan.CreateMacroDesc
 
getColNames() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DoubleColumnInList
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColAndScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColOrScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarAndColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarOrColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRoundWithNumDigitsDecimalToDecimal
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IdentityExpression
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNotNull
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNull
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColumnInList
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarDivideLongColumn
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncDoubleToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToDouble
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NotCol
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNotNull
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNull
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatScalarCol
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringLength
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStart
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStartLen
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDF
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
getColNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldString
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColAndCol
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColOrCol
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongColumn
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsFalse
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsTrue
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColCol
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol
 
getColNum1() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColCol
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColAndCol
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColOrCol
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongColumn
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColCol
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol
 
getColNum2() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColCol
 
getCols() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getCols() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getCols() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
getCols() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getCols() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
getCols() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnListDesc
 
getCols() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
getCols() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
getCols() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
getColsFromSelectExpr(SelectOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
Creates the list of internal column names from select expressions in a select operator.
getColsString() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getColStat(List<Integer>) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveTableScanRel
 
getColStatistics(ColumnStatisticsObj, String, String) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Convert ColumnStatisticsObj to ColStatistics
getColStatisticsFromExpression(HiveConf, Statistics, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get column statistics expression nodes
getColStatisticsFromExprMap(HiveConf, Statistics, Map<String, ExprNodeDesc>, RowSchema) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get column statistics from parent statistics.
getColStats() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsWork
 
getColType() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getColType() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
getColTypes() - Method in class org.apache.hadoop.hive.ql.plan.CreateMacroDesc
 
getColTypes() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
getColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
getColumn() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.BaseColumnInfo
 
getColumn(int, BytesRefArrayWritable) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Fetch all data in the buffer for a given column.
getColumn() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
getColumnAccessInfo() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Gets the column access information.
getColumnAccessInfo() - Method in class org.apache.hadoop.hive.ql.QueryPlan
Gets the column access information.
getColumnDesc() - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
getColumnExprMap() - Method in class org.apache.hadoop.hive.ql.exec.Operator
Returns a map of output column name to input expression map Note that currently it returns only key columns for ReduceSink and GroupBy operators.
getColumnExprProcessor() - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get ColumnExprProcessor.
getColumnIndexes() - Method in class org.apache.hadoop.hive.ql.plan.TruncateTableDesc
 
getColumnInfos() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getColumnInternalName(int) - Static method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getColumnMap() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
getColumnName() - Method in interface org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf
Get the simple column name.
getColumnName() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
getColumnNames(Properties) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getColumnNames(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.index.AbstractIndexHandler
 
getColumnNames() - Method in class org.apache.hadoop.hive.ql.io.orc.Reader.Options
 
getColumnNames(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
getColumnNamesFromFieldSchema(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getColumnNamesFromSortCols(List<Order>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getColumnNum() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
getColumnNumber() - Method in class org.apache.hadoop.hive.ql.io.RCFile.KeyBuffer
 
getColumnNumber(Configuration) - Static method in class org.apache.hadoop.hive.ql.io.RCFileOutputFormat
Returns the number of columns set in the conf for writers.
getColumnPath() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
getColumnProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory
 
getColumnProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBExprProcFactory
Instantiate column processor.
getColumnProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory
 
getColumnProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory
Instantiate column processor.
getColumnProcessor() - Static method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory
 
getColumns() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRawRecordMerger
Get the number of columns in the underlying rows.
getColumns(ASTNode, boolean) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Get the list of FieldSchema out of the ASTNode.
getColumns() - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
getColumns() - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
getColumns() - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeDesc
 
getColumns() - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
getColumns() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilege
 
getColumnsHeader() - Static method in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatUtils
 
getColumnStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.StripeStatistics
Return list of column statistics
getColumnStatisticsForColumn(String, String) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
getColumnStatisticsFromColName(String) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
getColumnStatisticsFromFQColName(String) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
getColumnStats() - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
getColumnStatsState() - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
getColumnType() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
getColumnTypes(Properties) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getColumnTypes() - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
getColumnTypes() - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
getCommand() - Method in interface org.apache.hadoop.hive.ql.HiveDriverRunHookContext
 
getCommand() - Method in class org.apache.hadoop.hive.ql.HiveDriverRunHookContextImpl
 
getCommand() - Method in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
getCommandType() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getComment() - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
getComment() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getComment() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getCommonCategory(TypeInfo, TypeInfo) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getCommonClass(TypeInfo, TypeInfo) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Find a common class that objects of both TypeInfo a and TypeInfo b can convert to.
getCommonClassForComparison(TypeInfo, TypeInfo) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Find a common class that objects of both TypeInfo a and TypeInfo b can convert to.
getCommonClassForUnionAll(TypeInfo, TypeInfo) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Find a common class for union-all operator
getCommonJoinTask() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
getCompactionType() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
Get what type of compaction is being done by a ALTER TABLE ...
getComparison() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
getComparisonExpr() - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
getComparisonOp() - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
getCompiler(HiveConf, ParseContext) - Static method in class org.apache.hadoop.hive.ql.parse.TaskCompilerFactory
Returns the appropriate compiler to translate the operator tree into executable units.
getCompleteName() - Method in class org.apache.hadoop.hive.ql.metadata.DummyPartition
 
getCompleteName() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getCompleteName() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getCompleteTaskList() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getCompressCodec() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getCompressed() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getCompressedKeyLength() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
getCompression() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the compression kind.
getCompressionCodec() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
 
getCompressionCodec() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Writer
Deprecated. 
getCompressionSize() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the buffer size for the compression.
getCompressor(CompressionCodec) - Static method in class org.apache.hadoop.hive.ql.io.CodecPool
Get a Compressor for the given CompressionCodec from the pool or a new one.
getCompressType() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getConditionEvaluator() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorFilterOperator
 
getConds() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getConds() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getCondsList() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getConf() - Method in class org.apache.hadoop.hive.ql.Context
 
getConf() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getConf() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
getConf() - Method in class org.apache.hadoop.hive.ql.HiveDriverRunHookContextImpl
 
getConf() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getConf() - Method in class org.apache.hadoop.hive.ql.index.TableBasedIndexHandler
 
getConf() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
 
getConf() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
getConf() - Method in class org.apache.hadoop.hive.ql.io.HivePassThroughOutputFormat
 
getConf() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockManagerCtx
 
getConf() - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
getConf() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getConf() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
getConf() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getConf() - Method in class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.GroupByOptimizerContext
 
getConf() - Method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.AnnotateOpTraitsProcCtx
 
getConf() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
getConf() - Method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.AnnotateStatsProcCtx
 
getConf() - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
getConf() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getConf() - Method in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
getConf() - Method in class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
getConf() - Method in class org.apache.hadoop.hive.ql.security.SessionStateConfigUserAuthenticator
 
getConf() - Method in class org.apache.hadoop.hive.ql.security.SessionStateUserAuthenticator
 
getConf() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getConfiguration() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getConfiguration() - Method in class org.apache.hadoop.hive.ql.io.AcidInputFormat.Options
 
getConfiguration() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
getConfirmedPartitionsForScan(QBParseInfo) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
getConsole() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
initialize or retrieve console object for SessionState.
getConstantDesc() - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
getConstExpr() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
getContentLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the length of the file.
getContentSummary(Path, JobConf) - Method in interface org.apache.hadoop.hive.ql.io.ContentSummaryInputFormat
 
getContentSummary(Path, JobConf) - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat
 
getContext() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
getContext() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getConvertedJoinOps() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
getConvertedNode(Node) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
getConverter(int) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.ArrayWritableGroupConverter
 
getConverter(int) - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.DataWritableGroupConverter
 
getCountDistint() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
getCounter() - Method in class org.apache.hadoop.hive.ql.udf.generic.UDTFCollector
 
getCounters() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getCounters() - Method in class org.apache.hadoop.hive.ql.exec.TaskHandle
 
getCounters() - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
getCounters() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getCountForMapJoinDumpFilePrefix() - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
getCpu() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCost
 
getCpuMSec() - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
getCreate(String) - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Prepares CREATE TABLE query
getCreateDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCreateFunctionDesc() - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
getCreateIndexDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCreateMacroDesc() - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
getCreateTableGrants() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getCreateTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCreateTblLikeDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCreateViewDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCreateVwDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCS(Path) - Method in class org.apache.hadoop.hive.ql.Context
 
getCS(String) - Method in class org.apache.hadoop.hive.ql.Context
 
getCtx() - Method in class org.apache.hadoop.hive.ql.DriverContext
 
getCurJobNo() - Method in class org.apache.hadoop.hive.ql.DriverContext
 
getCurrAliasId() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMapRedCtx
 
getCurrAliasId() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getCurrentArray() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.DataWritableGroupConverter
 
getCurrentBigBucketFile() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
getCurrentBlockLength() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
 
getCurrentBlockStart() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
getCurrentCompressedKeyLen() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
 
getCurrentDatabase() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getCurrentDB() - Static method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
getCurrentDirectories() - Method in interface org.apache.hadoop.hive.ql.io.AcidUtils.Directory
Get the list of base and delta directories that are valid and not obsolete.
getCurrentInputPath() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
getCurrentKey() - Method in class org.apache.hadoop.hive.ql.exec.tez.tools.InputMerger
 
getCurrentKeyBufferObj() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
return the KeyBuffer object used in the reader.
getCurrentKeyLength() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
 
getCurrentMapJoin() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
getCurrentRecord() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.DataWritableRecordConverter
 
getCurrentRoleNames() - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessController
 
getCurrentRoleNames() - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
 
getCurrentRoleNames() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
getCurrentRoleNames() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
getCurrentRoles() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
getCurrentRow() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
getCurrentRow(BytesRefArrayWritable) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
get the current row used,make sure called RCFile.Reader.next(LongWritable) first.
getCurrentTask() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.index.IndexWhereProcCtx
 
getCurrentTask() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
getCurrentTask() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinResolver.SkewJoinProcCtx
 
getCurrentValueBufferObj() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
return the ValueBuffer object used in the reader.
getCurrentValues() - Method in class org.apache.hadoop.hive.ql.exec.tez.tools.InputMerger
 
getCurrMapJoinOp() - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
getCurrPart() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
getCurrTask() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMapRedCtx
 
getCurrTask() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getCurrTbl() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
getCurrTopOp() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getCurrUnionOp() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getCustomBucketMapJoin() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getD() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
getData() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataOutputBuffer
Returns the current contents of the buffer.
getData() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
getDatabase() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
getDatabase(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get the database by name.
getDatabase() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
getDatabaseCurrent() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get the Database object for current database
getDatabaseName() - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
getDatabaseName() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getDatabaseName() - Method in class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
getDatabaseName() - Method in class org.apache.hadoop.hive.ql.plan.DropDatabaseDesc
 
getDatabaseName() - Method in class org.apache.hadoop.hive.ql.plan.LockDatabaseDesc
 
getDatabaseName() - Method in class org.apache.hadoop.hive.ql.plan.SwitchDatabaseDesc
 
getDatabaseName() - Method in class org.apache.hadoop.hive.ql.plan.UnlockDatabaseDesc
 
getDatabaseProperties() - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
getDatabaseProperties() - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
getDatabasesByPattern(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get all existing databases that match the given pattern.
getDataContainer() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DependencyKey
 
getDataLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.StripeInformation
Get the length of the stripe's data.
getDataLocation() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getDataLocation() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getDataSize() - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
getDataSizeFromColumnStats(long, List<ColStatistics>) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Compute raw data size from column statistics
getDateExprProcessor() - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get DateExprProcessor.
getDb() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getDbName() - Method in class org.apache.hadoop.hive.ql.index.IndexMetadataChangeWork
 
getDbName() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getDbName() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getDbName() - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
getDbName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableAlterPartDesc
 
getDbName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
getDbName() - Method in class org.apache.hadoop.hive.ql.plan.RenamePartitionDesc
 
getDbName() - Method in class org.apache.hadoop.hive.ql.plan.ShowColumnsDesc
 
getDbName() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
getDbName() - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
getDbName() - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
getDbname() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
 
getDbTableName(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Extract db and table name from dbtable string, where db and table are separated by "." If there is no db name part, set the current sessions default db
getDecimal(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
getDecimalPlaces() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRoundWithNumDigitsDecimalToDecimal
 
getDecimalPlaces() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.RoundWithNumDigitsDoubleToDouble
 
getDecimalTypeTypeInfo(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.ParseUtils
 
getDecompressor(CompressionCodec) - Static method in class org.apache.hadoop.hive.ql.io.CodecPool
Get a Decompressor for the given CompressionCodec from the pool or a new one.
getDefault() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
getDefaultArgOI() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
getDefaultDestDir(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
getDefaultDirName() - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
getDefaultExprProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory
 
getDefaultExprProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory
 
getDefaultExprProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactory
Instantiate default expression processor.
getDefaultExprProcessor() - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get DefaultExprProcessor.
getDefaultExprProcessor() - Static method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory
 
getDefaultInputFormat() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
getDefaultKey() - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
getDefaultNotificationInterval(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Gets the default notification interval to send progress updates to the tracker.
getDefaultOutputFormat() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
getDefaultPartitionName() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
Factory method to get the ColumnPrunerDefaultProc class.
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpProcFactory
 
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory
 
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory
 
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinProcFactory
 
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.PrunerOperatorFactory
Instantiate default processor.
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner
 
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getDefaultQueryOutputTableDesc(String, String, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
getDefaultRule() - Static method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory
 
getDefaultRule() - Static method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory
 
getDefaultSerdeProps() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
getDefaultSerName() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
getDefaultTableDesc(CreateTableDesc, String, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
getDefaultTableDesc(String, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor of MetadataTypedColumnsetSerDe with the separatorCode and column names (comma separated string).
getDefaultTableDesc(String, String, boolean) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor of MetadataTypedColumnsetSerDe with the separatorCode and column names (comma separated string), and whether the last column should take the rest of the line.
getDefaultTableDesc(String, String, String, boolean) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor of MetadataTypedColumnsetSerDe with the separatorCode and column names (comma separated string), and whether the last column should take the rest of the line.
getDefaultTableDesc(String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor of MetadataTypedColumnsetSerDe with the separatorCode.
getDefaultValueConverter() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
getDeferredJavaObject(int, VectorizedRowBatch, int, VectorExpressionWriter[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
getDeferredRebuild() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getDelegationToken(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getDeleteAggr(String, String) - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Prepares DELETE statement for cleanup.
getDeltas() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcNewSplit
 
getDeltas() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSplit
 
getDenominator() - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Gets the denominator.
getDenominator() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc.sampleDesc
 
getDependency(LineageInfo.DataContainer, FieldSchema) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo
Gets the dependency for a table, column tuple.
getDependency(Operator<? extends OperatorDesc>, ColumnInfo) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx.Index
Gets the dependency for an operator, columninfo tuple.
getDependency() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
getDependencyMap() - Method in class org.apache.hadoop.hive.ql.plan.TezWork
 
getDependencyTaskForMultiInsert() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
Returns dependencyTaskForMultiInsert initializing it if necessary.
getDependentTasks() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
getDependentTasks() - Method in class org.apache.hadoop.hive.ql.exec.Task
The default dependent tasks are just child tasks, but different types could implement their own (e.g.
getDesc() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
getDescDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDescFunctionDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToDecimal
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToDate
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDate
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDecimal
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColAndCol
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColOrCol
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalColumnInList
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalToStringUnaryUDF
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DoubleColumnInList
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColAndScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColOrScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDecimalColumnInList
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDoubleColumnInList
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterExprAndExpr
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterExprOrExpr
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterLongColumnInList
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarAndColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarOrColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStringColumnInList
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDoubleToDecimal
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLogWithBaseDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLogWithBaseLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToDecimal
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToString
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerLongToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRand
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRandNoSeed
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRoundWithNumDigitsDecimalToDecimal
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IdentityExpression
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNotNull
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNull
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColumnInList
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarDivideLongColumn
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongToStringUnaryUDF
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NotCol
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.PosModDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.PosModLongToLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.RoundWithNumDigitsDoubleToDouble
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsFalse
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNotNull
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNull
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsTrue
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringColumnInList
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColCol
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatScalarCol
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringLength
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStart
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStartLen
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDF
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDFDirect
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorCoalesce
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColCol
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldString
 
getDescriptor() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
getDescTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDeserializer() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getDeserializer() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getDeserializer(Configuration) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
Return a deserializer object corresponding to the partitionDesc.
getDeserializer() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
Return a deserializer object corresponding to the tableDesc.
getDeserializerClass() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getDestCubes() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestFileForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getDestForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestGroupingSets() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestination() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFQueryInputDef
 
getDestinationCreateTable() - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
getDestinationTable() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableExchangePartition
 
getDestLimit(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestPartitionForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getDestRollups() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestTableForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getDestTableId() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getDestTableId() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getDestToAggregationExprs() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestToClusterBy() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestToDistinctFuncExprs() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestToDistributeBy() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestToGroupBy() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestToHaving() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestToLateralView() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestToLimit() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestToOrderBy() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestToSortBy() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestToWhereExpr() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestTypeForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getDimensionId() - Method in class org.apache.hadoop.hive.ql.metadata.Dimension
 
getDimensionType() - Method in class org.apache.hadoop.hive.ql.metadata.Dimension
 
getDir() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
getDirectFetchOp() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getDirection() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.BoundarySpec
 
getDirection() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.CurrentRowSpec
 
getDirection() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.RangeBoundarySpec
 
getDirection() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.ValueBoundarySpec
 
getDirection() - Method in class org.apache.hadoop.hive.ql.plan.ptf.BoundaryDef
 
getDirection() - Method in class org.apache.hadoop.hive.ql.plan.ptf.CurrentRowDef
 
getDirectWorks() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
getDirName() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getDirToTaskMap() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx
 
getDispatchedList() - Method in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
 
getDispatchedList() - Method in class org.apache.hadoop.hive.ql.lib.TaskGraphWalker
 
getDisplayName() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
Get the display name for this function.
getDisplayName() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.AbstractGenericUDFEWAHBitmapBop
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.AbstractGenericUDFReflect
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
Get the String to be displayed in explain.
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFAbs
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFArray
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFArrayContains
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFAssertTrue
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBasePad
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseTrim
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBetween
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCase
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCoalesce
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcat
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcatWS
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDate
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateAdd
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateDiff
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateSub
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDecode
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFElt
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFEncode
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFEWAHBitmapEmpty
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFField
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFloorCeilBase
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFormatNumber
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFromUtcTimestamp
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFHash
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIf
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIn
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIndex
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFInFile
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFInstr
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLocate
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLower
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMap
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMapKeys
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMapValues
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFNamedStruct
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFNvl
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPAnd
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNot
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotNull
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNull
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPOr
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPower
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPrintf
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFRound
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSentences
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSize
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSortArray
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSplit
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStringToMap
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStruct
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTimestamp
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToBinary
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToChar
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToDate
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToDecimal
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToUnixTimeStamp
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToUtcTimestamp
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToVarchar
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTranslate
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUnion
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUpper
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFWhen
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.UDFCurrentDB
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.xml.GenericUDFXPath
 
getDistinct() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getDistinctBufferSetCount() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferBatch
number of distinct aggregation buffer sets (ie.
getDistinctColumnIndices() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getDistinctFuncExprsForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDistinctRowCount(RelNode, BitSet, RexNode) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.stats.HiveRelMdDistinctRowCount
 
getDistinctRowCount(RelNode, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.stats.HiveRelMdDistinctRowCount
 
getDistinctRowCount(JoinRelBase, BitSet, RexNode) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.stats.HiveRelMdDistinctRowCount
 
getDistKeyLength() - Method in class org.apache.hadoop.hive.ql.io.HiveKey
 
getDistributeByForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
Get the Distribute By AST for the clause.
getDivisor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.PosModDoubleToDouble
 
getDivisor() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.PosModLongToLong
 
getDone() - Static method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapper
 
getDone() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getDone() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getDoneJoins() - Method in class org.apache.hadoop.hive.ql.optimizer.SkewJoinOptimizer.SkewJoinOptProcCtx
 
getDoubleValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
getDoubleValue(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
getDPColNames() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getDPCtx(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getDPCtx() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
getDPCtx() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getDpSortState() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getDriverContext() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getDropDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDropFunctionDesc() - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
getDropIdxDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDropMacroDesc() - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
getDroppedColumns() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
getDropTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDummyOps() - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
getDummyParentOp() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
getDummyParentOp() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getDummyStream() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
getDumpFilePrefix() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getDumpFilePrefix() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getDynPartCtx() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
getDynPartCtx() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
getDynPartCtx() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getEachColumnUncompressedValueLen() - Method in class org.apache.hadoop.hive.ql.io.RCFile.KeyBuffer
 
getEachColumnValueLen() - Method in class org.apache.hadoop.hive.ql.io.RCFile.KeyBuffer
 
getEdgeProperty(BaseWork, BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
returns the edge type connecting work a and b
getEdgeType() - Method in class org.apache.hadoop.hive.ql.plan.TezEdgeProperty
 
getEdgeType(BaseWork, BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
 
getEmptyTable(String, String) - Static method in class org.apache.hadoop.hive.ql.metadata.Table
Initialize an emtpy table.
getEnd() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFrameSpec
 
getEnd() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFrameDef
 
getEndTime(String) - Method in class org.apache.hadoop.hive.ql.log.PerfLogger
 
getEquiJoinPredicateElements() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinPredicateInfo
 
getError() - Method in class org.apache.hadoop.hive.ql.exec.errors.ErrorAndSolution
 
getError() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getErrorAndSolution() - Method in class org.apache.hadoop.hive.ql.exec.errors.DataCorruptErrorHeuristic
 
getErrorAndSolution() - Method in interface org.apache.hadoop.hive.ql.exec.errors.ErrorHeuristic
Examine the hive query, job configuration, and the lines from the task log seen so far though processLogLine() and generate a possible cause/solution.
getErrorAndSolution() - Method in class org.apache.hadoop.hive.ql.exec.errors.MapAggrMemErrorHeuristic
 
getErrorAndSolution() - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
getErrorAndSolution() - Method in class org.apache.hadoop.hive.ql.exec.errors.ScriptErrorHeuristic
 
getErrorCode() - Method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
getErrorCode() - Method in class org.apache.hadoop.hive.ql.exec.mr.JobDebugger
 
getErrorCodedMsg() - Method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
getErrorCodedMsg(String...) - Method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
getErrorCodePattern() - Static method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
getErrorMessage(RecognitionException, String[]) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveLexerX
 
getErrorMessage() - Method in class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
 
getErrorMsg() - Method in class org.apache.hadoop.hive.ql.Driver
 
getErrorMsg(String) - Static method in enum org.apache.hadoop.hive.ql.ErrorMsg
Given an error message string, returns the ErrorMsg object associated with it.
getErrorMsg(int) - Static method in enum org.apache.hadoop.hive.ql.ErrorMsg
Given an error code, returns the ErrorMsg object associated with it.
getErrors() - Method in class org.apache.hadoop.hive.ql.exec.errors.TaskLogProcessor
Processes the provided task logs using the known error heuristics to get the matching errors.
getErrors() - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveLexerX
 
getErrorSrcNode() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getErrRecordReaderClass() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getErrStream() - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
getEval() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
getEvalMethod(List<TypeInfo>) - Method in class org.apache.hadoop.hive.ql.exec.ComparisonOpMethodResolver
 
getEvalMethod(List<TypeInfo>) - Method in class org.apache.hadoop.hive.ql.exec.DefaultUDFMethodResolver
Gets the evaluate method for the UDF given the parameter types.
getEvalMethod(List<TypeInfo>) - Method in class org.apache.hadoop.hive.ql.exec.NumericOpMethodResolver
 
getEvalMethod(List<TypeInfo>) - Method in interface org.apache.hadoop.hive.ql.exec.UDFMethodResolver
Gets the evaluate method for the UDF given the parameter types.
getEvaluator(GenericUDAFParameterInfo) - Method in class org.apache.hadoop.hive.ql.udf.generic.AbstractGenericUDAFResolver
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.AbstractGenericUDAFResolver
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCollectList
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCollectSet
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount
 
getEvaluator(GenericUDAFParameterInfo) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovarianceSample
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEWAHBitmap
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFFirstValue
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLastValue
 
getEvaluator(GenericUDAFParameterInfo) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFNTile
 
getEvaluator(GenericUDAFParameterInfo) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank
 
getEvaluator(TypeInfo[]) - Method in interface org.apache.hadoop.hive.ql.udf.generic.GenericUDAFResolver
Deprecated. Get the evaluator for the parameter types.
getEvaluator(GenericUDAFParameterInfo) - Method in interface org.apache.hadoop.hive.ql.udf.generic.GenericUDAFResolver2
Get the evaluator for the parameter types.
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRowNumber
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStd
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStdSample
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVarianceSample
 
getEvaluator() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
 
getEvaluatorClass(List<TypeInfo>) - Method in class org.apache.hadoop.hive.ql.exec.DefaultUDAFEvaluatorResolver
Gets the evaluator class for the UDAF given the parameter types.
getEvaluatorClass(List<TypeInfo>) - Method in class org.apache.hadoop.hive.ql.exec.NumericUDAFEvaluatorResolver
 
getEvaluatorClass(List<TypeInfo>) - Method in interface org.apache.hadoop.hive.ql.exec.UDAFEvaluatorResolver
Gets the evaluator class corresponding to the passed parameter list.
getExecContext() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getExecJarPathLocal() - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
getExitVal() - Method in class org.apache.hadoop.hive.ql.exec.TaskResult
 
getExpectView() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getExpectView() - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
getExplain() - Method in class org.apache.hadoop.hive.ql.Context
Find whether the current query is an explain query
getExplainLogical() - Method in class org.apache.hadoop.hive.ql.Context
Find whether the current query is a logical explain query
getExplainOrder(HiveConf, List<Task<?>>) - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.StageIDsRearranger
 
getExpr() - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
Return child evaluators if exist
getExpr() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
getExpr() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
getExprDependency(LineageCtx, Operator<? extends OperatorDesc>, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory
Gets the expression dependencies for the expression.
getExpression() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionExpression
 
getExpression(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
Retrieves the ColumnInfo corresponding to a source expression which exactly matches the string rendering of the given ASTNode.
getExpression() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.ValueBoundarySpec
 
getExpression() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowExpressionSpec
 
getExpressionDef() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ValueBoundaryDef
 
getExpressionMap() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getExpressions() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderSpec
 
getExpressions() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionSpec
 
getExpressions() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getExpressions() - Method in class org.apache.hadoop.hive.ql.plan.ptf.OrderDef
 
getExpressions() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionDef
 
getExpressionSource(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
Retrieves the source expression matching a given ASTNode's string rendering exactly.
getExpressionTreeString() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFExpressionDef
 
getExpressionTreeString() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFInputDef
 
getExpressionWriters(List<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory
Helper function to create an array of writers from a list of expression descriptors.
getExpressionWriters(StructObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory
Returns VectorExpressionWriter objects for the fields in the given object inspector.
getExprEvaluator() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFExpressionDef
 
getExprEvaluator() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ValueBoundaryDef
 
getExprEvaluator() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
getExprListString(Collection<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
getExprNode() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFExpressionDef
 
getExprNode() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ValueBoundaryDef
 
getExprNodeDesc() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc.ExprNodeDescEqualityWrapper
 
getExprs() - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Gets the ON part's expression list.
getExprs() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getExprs() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getExprsStringMap() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeNullDesc
 
getExprToColumnAlias(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getExtended() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
getExternalTmpPath(URI) - Method in class org.apache.hadoop.hive.ql.Context
Get a path to store tmp data destined for external URI.
getExtractProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory
 
getExtTmpPathRelTo(URI) - Method in class org.apache.hadoop.hive.ql.Context
This is similar to getExternalTmpPath() with difference being this method returns temp path within passed in uri, whereas getExternalTmpPath() ignores passed in path and returns temp path within /tmp
getFalseCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.BooleanColumnStatistics
 
getFeedSubscribers() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getFetchExpr() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveSortRel
 
getFetchOperators() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
getFetchSink() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getFetchSource() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getFetchTabledesc() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getFetchTask() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
getFetchTask() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getFetchTask() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getFetchTask() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
getFetchTask() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getField() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
getField(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getFieldDelim() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getFieldDelim() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getFieldEscape() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getFieldEscape() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getFieldMap(String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getFieldName() - Method in class org.apache.hadoop.hive.ql.plan.ExplosionDesc
 
getFieldName() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
getFieldProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory
 
getFieldProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory
 
getFieldProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactory
Instantiate field processor.
getFields() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getFieldSchema() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DependencyKey
 
getFieldSchemasFromColumnInfo(ArrayList<ColumnInfo>, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Convert the ColumnInfo to FieldSchema.
getFieldSchemasFromColumnList(List<ExprNodeDesc>, List<String>, int, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Convert the ColumnList to FieldSchema list.
getFieldSchemasFromColumnList(List<ExprNodeDesc>, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Convert the ColumnList to FieldSchema list.
getFieldSchemasFromColumnListWithLength(List<ExprNodeDesc>, List<List<Integer>>, List<String>, int, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Convert the ColumnList to FieldSchema list.
getFieldSchemasFromRowSchema(RowSchema, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Convert the RowSchema to FieldSchema list.
getFieldSchemaString(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getFieldsFromDeserializer(String, Deserializer) - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getFileExtension(JobConf, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Deprecated. Use Utilities.getFileExtension(JobConf, boolean, HiveOutputFormat)
getFileExtension(JobConf, boolean, HiveOutputFormat<?, ?>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Based on compression option, output format, and configured output codec - get extension for output file.
getFileId() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
getFileKey() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
getFileNameFromDirName(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getFileSinkProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory
 
getFileSizeForPartitions(HiveConf, List<Partition>) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Find the bytes on disks occupied by list of partitions
getFileSizeForTable(HiveConf, Table) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Find the bytes on disk occupied by a table
getFilesystem() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
getFilterExpr() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getFilterExprString() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getFilterMap() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getFilterMap() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getFilterMap() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getFilterMapString() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getFilterMapString() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getFilterProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
Factory method to get the ColumnPrunerFilterProc class.
getFilterProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBPartitionProcFactory
 
getFilterProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBProcFactory
 
getFilterProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpProcFactory
 
getFilterProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory
 
getFilterProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.OpProcFactory
 
getFilterProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner
 
getFilterProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getFilterRule() - Static method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory
 
getFilters() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getFilters() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getFilters() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getFiltersForPushing() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getFiltersStringMap() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
Get the string representation of filters.
getFilterTraitSet(RelOptCluster, RelTraitSet, RelNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.TraitsUtil
 
getFinalCandidates() - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Returns the list of pushdown expressions for each alias that appear in the current operator's RowResolver.
getFinalDirName() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getFinalPath(String, Path, String) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
Update the final paths according to tmpPath.
getfInfo() - Method in class org.apache.hadoop.hive.ql.exec.WindowFunctionInfo
 
getFirst() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.Pair
 
getFirst() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getFirstArgOI() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
getFixedStringSizeForType(PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.StringHelper
Helper function to help GenericUDFs determine the return type character length for char/varchar.
getFnName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator
 
getFooterCount(TableDesc, JobConf) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Get footer line count for a table.
getFooterLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.StripeInformation
Get the length of the stripe's tail section, which contains its index.
getForHiveCommand(String[], HiveConf) - Static method in class org.apache.hadoop.hive.ql.processors.CommandProcessorFactory
 
getFormatter(HiveConf) - Static method in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatUtils
 
getForwardProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory
 
getFromPath() - Method in class org.apache.hadoop.hive.ql.plan.CopyWork
 
getFromPool() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorUtilBatchObjectPool
 
getFsopToTable() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getFullDPSpecs(Configuration, DynamicPartitionCtx) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Construct a list of full partition spec from Dynamic Partition Context and the directory names corresponding to these dynamic partitions.
getFullQualifedColNameFromExprs(List<ExprNodeDesc>, Map<String, ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Try to get fully qualified column name from expression node
getFullyQualifiedColName() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
getFullyQualifiedColumnName(String, String) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Returns fully qualified name of column
getFullyQualifiedColumnName(String, String, String) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Returns fully qualified name of column
getFullyQualifiedColumnName(String, String, String, String) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Returns fully qualified name of column
getFunc() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDF
 
getFuncDef() - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
getFuncExprNodeDesc(String, ExprNodeDesc...) - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
 
getFuncText() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
getFunction(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getFunction() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec
 
getFunctionClass() - Method in interface org.apache.hadoop.hive.ql.exec.CommonFunctionInfo
 
getFunctionClass() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
Get the Class of the UDF.
getFunctionClass() - Method in exception org.apache.hadoop.hive.ql.exec.UDFArgumentException
 
getFunctionClass() - Method in class org.apache.hadoop.hive.ql.exec.WindowFunctionInfo
 
getFunctionInfo(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getFunctionName() - Method in class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
getFunctionName() - Method in class org.apache.hadoop.hive.ql.plan.DropFunctionDesc
 
getFunctionNames() - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns a set of registered function names.
getFunctionNames(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns a set of registered function names.
getFunctions(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getFunctionSynonyms(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns the set of synonyms of the supplied function.
getFunctionText(ASTNode, boolean) - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
 
getfWork() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsWork
 
getGbKeyNameList() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getGenericFuncProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory
 
getGenericFuncProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory
 
getGenericFuncProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactory
Instantiate generic function processor.
getGenericFuncProcessor() - Static method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory
 
getGenericUDAFEvaluator(String, List<ObjectInspector>, boolean, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Get the GenericUDAF evaluator for the name and argumentClasses.
getGenericUDAFEvaluator() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getGenericUDAFEvaluatorClassName() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getGenericUDAFName() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getGenericUDAFResolver() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
Get the GenericUDAFResolver object for the function.
getGenericUDAFResolver(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getGenericUDAFWritableEvaluator() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getGenericUDF() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
Get a new GenericUDF object for the function.
getGenericUDF() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
getGenericUDFClassName() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
getGenericUDFForAnd() - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
A shortcut to get the "and" GenericUDF.
getGenericUDFForIndex() - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
A shortcut to get the "index" GenericUDF.
getGenericUDTF() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
Get a new GenericUDTF object for the function.
getGenericUDTF() - Method in class org.apache.hadoop.hive.ql.plan.UDTFDesc
 
getGenericWindowingEvaluator(String, List<ObjectInspector>, boolean, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getGlobalLimit() - Method in class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
getGlobalLimitCtx() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getGrant() - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
getGrantDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getGrantor() - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
getGrantor() - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
getGrantor() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
getGrantorPrincipal() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeInfo
 
getGrantorType() - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
getGrantorType() - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
getGrantorType() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
getGrantRevokeRoleDDL() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getGrantTime() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeInfo
 
getGrantTime() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
getGroup() - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getGroupByForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getGroupByMemoryUsage() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getGroupByProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
Factory method to get the ColumnPrunerGroupByProc class.
getGroupByProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getGroupByProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory
 
getGroupByProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory
 
getGroupByRule() - Static method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory
 
getGroupByRule() - Static method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory
 
getGroupGrants() - Method in class org.apache.hadoop.hive.ql.session.CreateTableAutomaticGrant
 
getGroupingSetPosition() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getGroupKeyNotReductionKey() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getGroupKeyObject() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getGroupKeyObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getGroupNames() - Method in class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
getGroupNames() - Method in interface org.apache.hadoop.hive.ql.security.HiveAuthenticationProvider
 
getGroupNames() - Method in class org.apache.hadoop.hive.ql.security.SessionStateConfigUserAuthenticator
 
getGroupNames() - Method in class org.apache.hadoop.hive.ql.security.SessionStateUserAuthenticator
 
getGroupOpToInputTables() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getHadoopSupportsSplittable() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getHandlerClsName() - Method in enum org.apache.hadoop.hive.ql.index.HiveIndex.IndexType
 
getHandleSkewJoin() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getHarUri(URI, HadoopShims) - Method in class org.apache.hadoop.hive.ql.exec.ArchiveUtils.HarPathHelper
 
getHashedStatsPrefix(String, int) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
If statsPrefix's length is greater than maxPrefixLength and maxPrefixLength > 0, then it returns an MD5 hash of statsPrefix followed by path separator, otherwise it returns statsPrefix
getHashtableMemoryUsage() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getHashTableMemoryUsage() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getHasVariableSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferBatch
returns True if any of the aggregators has a variable size
getHavingForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getHdfsTmpDir() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
getHeaderCount(TableDesc) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Get header line count for a table.
getHighestSamplePercentage(MapWork) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Returns the highest sample percentage of any alias in the given MapWork
getHints() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getHistFileName() - Method in interface org.apache.hadoop.hive.ql.history.HiveHistory
 
getHistFileName() - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
 
getHive() - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getHive() - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContext
 
getHive() - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
getHiveConf() - Method in class org.apache.hadoop.hive.ql.plan.TezEdgeProperty
 
getHiveDb() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
getHiveHistory() - Method in class org.apache.hadoop.hive.ql.session.SessionState
get hiveHitsory object which does structured logging.
getHiveJarDirectory(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
getHiveLockMode() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLock
 
getHiveLockMode() - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock
 
getHiveLockObject() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLock
 
getHiveLockObject() - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock
 
getHiveLocks() - Method in class org.apache.hadoop.hive.ql.Context
 
getHiveMetastoreClient() - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveMetastoreClientFactory
 
getHiveMetastoreClient() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveMetastoreClientFactoryImpl
 
getHiveObj() - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
getHiveOperation() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getHivePrincipalType(PrincipalType) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
Convert thrift principal type to authorization plugin principal type
getHivePrivilegeObjectType(Entity.Type) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
Convert thrift object type to hive authorization plugin object type
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer.PTFHiveSequenceFileOutputFormat
 
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.ql.io.avro.AvroContainerOutputFormat
 
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.ql.io.HiveBinaryOutputFormat
create the final out file, and output row by row.
getHiveRecordWriter(JobConf, TableDesc, Class<? extends Writable>, FileSinkDesc, Path, Reporter) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
 
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
create the final out file, and output row by row.
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.ql.io.HiveNullValueSequenceFileOutputFormat
 
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in interface org.apache.hadoop.hive.ql.io.HiveOutputFormat
create the final out file and get some specific settings.
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.ql.io.HivePassThroughOutputFormat
 
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
create the final out file, and output an empty key as the key.
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcOutputFormat
 
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.ql.io.parquet.MapredParquetOutputFormat
Create the parquet schema from the hive schema, and return the RecordWriterWrapper which contains the real output format
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.ql.io.RCFileOutputFormat
create the final out file.
getHiveStats() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.RelOptHiveTable
 
getHiveTableMD() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.RelOptHiveTable
 
getHiveTxnManager() - Method in class org.apache.hadoop.hive.ql.Context
 
getHiveVariables() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getHoldDDLTime() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getHooks(HiveConf, HiveConf.ConfVars, Class<T>) - Static method in class org.apache.hadoop.hive.ql.hooks.HookUtils
Returns the hooks specified in a configuration variable.
getHookType() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getId() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getId() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getId() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getIdColumnName() - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Returns the name of the column storing the key for statistics.
getIdentifier() - Method in class org.apache.hadoop.hive.ql.exec.Operator
This function is not named getId(), to make sure java serialization does NOT serialize it.
getIdToTableNameMap() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getIdToTableNameMap() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getIdToTableNameMap() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getIdxProps() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getIfExists() - Method in class org.apache.hadoop.hive.ql.plan.DropDatabaseDesc
 
getIfExists() - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
getIfNotExists() - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
getIfNotExists() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getIfNotExists() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
getIfNotExists() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getIgnoreProtection() - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
getInclude() - Method in class org.apache.hadoop.hive.ql.io.orc.Reader.Options
 
getIncompleteStatsTabNames() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.stats.CBOTableStatsValidator
 
getIndex() - Method in interface org.apache.hadoop.hive.ql.exec.PTFPartition.PTFPartitionIterator
 
getIndex() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferRow
cached index used by VectorAggregationBufferBatch.
getIndex(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getIndex(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getIndex(String, String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getIndex() - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx
Gets the dependency index.
getIndexColumnsHeader() - Static method in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatUtils
 
getIndexComment() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getIndexedCols() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getIndexes(String, String, short) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getIndexes(Table, List<String>) - Static method in class org.apache.hadoop.hive.ql.optimizer.IndexUtils
Get a list of indexes on a table that match given types.
getIndexes() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.BucketCol
 
getIndexes() - Method in interface org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.BucketSortCol
 
getIndexes() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.SortCol
 
getIndexFiles(String) - Static method in class org.apache.hadoop.hive.ql.index.HiveIndexedInputFormat
 
getIndexHandler(HiveConf, String) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
getIndexInputFormat() - Method in class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
getIndexIntermediateFile() - Method in class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
getIndexIntermediateFile() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getIndexLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.StripeInformation
Get the length of the stripe's indexes.
getIndexName() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
getIndexName() - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
getIndexName() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getIndexName() - Method in class org.apache.hadoop.hive.ql.plan.DropIndexDesc
 
getIndexTableName() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getIndexTbl() - Method in class org.apache.hadoop.hive.ql.index.IndexMetadataChangeWork
 
getIndexType(String) - Static method in class org.apache.hadoop.hive.ql.index.HiveIndex
 
getIndexTypeByClassName(String) - Static method in class org.apache.hadoop.hive.ql.index.HiveIndex
 
getIndexTypeHandlerClass() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getInfoStream() - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
getInheritTableSpecs() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getInitialized() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getInListValues() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalColumnInList
 
getInListValues() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DoubleColumnInList
 
getInListValues() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDecimalColumnInList
 
getInListValues() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDoubleColumnInList
 
getInListValues() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterLongColumnInList
 
getInListValues() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStringColumnInList
 
getInListValues() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColumnInList
 
getInListValues() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringColumnInList
 
getInput(String) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezContext
 
getInput() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
getInput() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFInputSpec
 
getInput() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFQueryInputSpec
 
getInput() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
getInput() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFInputDef
 
getInput() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFQueryInputDef
 
getInputAliases() - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
getInputCol() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToString
 
getInputCol() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringColumnInList
 
getInputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToDecimal
 
getInputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToDate
 
getInputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDate
 
getInputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDecimal
 
getInputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalToStringUnaryUDF
 
getInputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToDouble
 
getInputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToLong
 
getInputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDoubleToDecimal
 
getInputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToDecimal
 
getInputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongToStringUnaryUDF
 
getInputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDFDirect
 
getInputColumnLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getInputColumns() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorCoalesce
 
getInputDBLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getInputDir() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
getInputDir() - Method in class org.apache.hadoop.hive.ql.parse.AlterTablePartMergeFilesDesc
 
getInputDir() - Method in class org.apache.hadoop.hive.ql.plan.TruncateTableDesc
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFAvgDecimal
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCount
 
getInputExpression() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFSumDecimal
 
getInputFileChangeSensitive() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getInputFileFormatClass() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getInputFileFormatClass() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getInputFileFormatClassName() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getInputFileFormatClassName() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getInputformat() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
getInputformat() - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanWork
 
getInputformat() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
getInputFormat() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
getInputFormat() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getInputFormat() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getInputFormat() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getInputformat() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getInputFormatChecker(Class<?>) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
get an InputFormatChecker for a file format.
getInputFormatClass() - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
getInputFormatClass() - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
 
getInputFormatClass() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getInputFormatClass() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getInputFormatClassName() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getInputFormatFromCache(Class, JobConf) - Static method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
getInputObjInspectors() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getInputOI() - Method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
getInputOperator() - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcCtx
Gets the input operator.
getInputPath() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
getInputPath() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
getInputPaths(JobConf, MapWork, Path, Context) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Computes a list of all input paths needed to compute the given MapWork.
getInputPaths() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
getInputPaths() - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanWork
 
getInputPathsForPartialScan(QBParseInfo, StringBuffer) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
getInputPathsTez(JobConf, MapWork) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
On Tez we're not creating dummy files when getting/setting input paths.
getInputPathToContentSummary() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getInputPrivs(HiveOperationType) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.Operation2Privilege
 
getInputPruning() - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Gets the flag that indicates whether input pruning is possible.
getInputPruning() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc.sampleDesc
 
getInputRequiredPrivileges() - Method in enum org.apache.hadoop.hive.ql.plan.HiveOperation
 
getInputRR() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getInputs() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getInputs() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
Get the input set.
getInputs() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getInputs() - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContext
The following methods will only be available to hooks executing postAnalyze.
getInputs() - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
getInputs() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getInputs() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
getInputs() - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
getInputs() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getInputSplit() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
getInputSplitShim() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
getInputSummary(Context, MapWork, PathFilter) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Calculate the total size of input files.
getInputTableLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getInputTableList() - Method in class org.apache.hadoop.hive.ql.tools.LineageInfo
 
getInputToDPCols() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getInputTypes() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression
 
getInputUserLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getInRecordWriterClass() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getInsert(String) - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Prepares INSERT statement for statistic publishing.
getInspector() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
getInstance() - Static method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
Singleton
getInstance() - Static method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
getInstance(ParseContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getInstance(ParseContext, Hive, String, String, String) - Static method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
getIntermediateFileTableDesc(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor for intermediate files.
getInternalColumnNamesFromSignature(List<ColumnInfo>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getInternalName() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
getInvRslvMap() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getIo() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCost
 
getIOContext() - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
getIoCxt() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
getIOExceptions() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
getIsAlterViewAs() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getIsBytesNull(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
getIsConstant() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
getIsDecimalNull(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
getIsDfsDir() - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
getIsDfsDir() - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
getIsDoubleNull(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
getIsDropIfExists() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getIsExprResolver() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getIsHidden() - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
getIsList() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
getIsLongNull(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
getIsMetadataOnly() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getIsPartitionColOrVirtualCol() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
getIsQuery() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getIsSamplingPred() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
getIsSilent() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getIsSilent() - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
getIsSubQ() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getIsVerbose() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getIsVirtualCol() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
getJc() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
getJob() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
getJobConf() - Method in class org.apache.hadoop.hive.ql.exec.MapredContext
Returns JobConf.
getJobEndMsg(JobID) - Static method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
this msg pattern is used to track when a job is successfully done.
getJobId() - Method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
getJobID() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getJobId() - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
getJobInfoMap() - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryViewer
 
getJobProperties() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getJoin(RelOptCluster, RelNode, RelNode, RexNode, JoinRelType) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveJoinRel
 
getJoinAlgorithm() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveJoinRel
 
getJoinAliases() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
getJoinCond() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getJoinConditionAST() - Method in class org.apache.hadoop.hive.ql.parse.QBSubQuery
 
getJoinConditionAST() - Method in interface org.apache.hadoop.hive.ql.parse.SubQueryUtils.ISubQueryJoinInfo
 
getJoinCondString() - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
getJoinContext() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getJoinCount() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
getJoinExpr() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getJoinKeyExprsFromLeft() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinLeafPredicateInfo
 
getJoinKeyExprsFromRight() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinLeafPredicateInfo
 
getJoinProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
The Factory method to get ColumnJoinProc class.
getJoinProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getJoinProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory
 
getJoinProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory
 
getJoinProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinProcFactory
 
getJoinProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getJoinPrunedColLists() - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
 
getJoinRule() - Static method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory
 
getJoinRule() - Static method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory
 
getJoinSrc() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getJoinTraitSet(RelOptCluster, RelTraitSet) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.TraitsUtil
 
getJoinTree() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getJoinType() - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
getJoinType() - Method in class org.apache.hadoop.hive.ql.parse.QBSubQuery
 
getJoinType() - Method in interface org.apache.hadoop.hive.ql.parse.SubQueryUtils.ISubQueryJoinInfo
 
getJSONKeyValue(Object, Object) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getJSONLogicalPlan(PrintStream, ExplainWork) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
getJSONMap(Map) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getJSONPlan(PrintStream, ExplainWork) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
getJSONPlan(PrintStream, String, List<Task<?>>, Task<?>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
getJSONQuery(Query) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getJSONValue(Object) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getKeyArray() - Method in class org.apache.hadoop.hive.ql.exec.KeyWrapper
 
getKeyArray() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
getKeyBuffer() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
getKeyBuffer() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
getKeyBuffer() - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
getKeyClass() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeRecordReader
 
getKeyClass() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
getKeyClass() - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
getKeyCols() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getKeyColString() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getKeyContext() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainerSerDe
 
getKeyDesc() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getKeyEval() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator
 
getKeyExpressions() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
getKeyExprMap() - Method in class org.apache.hadoop.hive.ql.optimizer.SortBucketJoinProcCtx
 
getKeyLength() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyObject
 
getKeyLength() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
getKeys() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getKeys() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getKeys() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getKeySerializeInfo() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getKeysFixedSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapperBatch
Returns the compiled fixed size for the key wrappers.
getKeysSerializeInfos() - Method in class org.apache.hadoop.hive.ql.plan.DemuxDesc
 
getKeysString() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getKeysString() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getKeyString() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getKeyTableDesc() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getKeyTableDesc() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getKeyTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getKeyTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getKeyWrapper() - Method in class org.apache.hadoop.hive.ql.exec.KeyWrapperFactory
 
getLang() - Method in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getLastCommand() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getLastInputPath() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
getLastMapRedStatsList() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getLastReduceLimitDesc() - Method in class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
getLateralViewForwardProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
 
getLateralViewForwardProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory
 
getLateralViewJoinProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
 
getLateralViewJoinProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getLateralViewJoinProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory
 
getLateralViewsForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getLbCtx() - Method in class org.apache.hadoop.hive.ql.parse.AlterTablePartMergeFilesDesc
 
getLbCtx() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
getLbCtx() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getLbCtx() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getLbCtx() - Method in class org.apache.hadoop.hive.ql.plan.TruncateTableDesc
 
getLbLocationMap() - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
getLeadLagExprs() - Method in class org.apache.hadoop.hive.ql.parse.LeadLagInfo
 
getLeastNumRows() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsWork
 
getLeastNumRows() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getLeastRows() - Method in class org.apache.hadoop.hive.ql.plan.LimitDesc
 
getLeaves() - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument
Get the leaf predicates that are required to evaluate the predicate.
getLeaves() - Method in class org.apache.hadoop.hive.ql.plan.TezWork
getLeaves returns all nodes that do not have a child
getLeft() - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
getLeft() - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
getLeftAlias() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
returns left alias if any - this is used for merging later on.
getLeftAliases() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getLength() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStartLen
 
getLength() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getLength(int) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getLength() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
getLength(int) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns the length of the ith Path.
getLength() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
getLength() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Returns the length of the input.
getLength() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataOutputBuffer
Returns the length of the valid data currently in the buffer.
getLength() - Method in class org.apache.hadoop.hive.ql.io.NullRowsInputFormat.DummyInputSplit
 
getLength() - Method in class org.apache.hadoop.hive.ql.io.orc.Reader.Options
 
getLength() - Method in interface org.apache.hadoop.hive.ql.io.orc.StripeInformation
Get the total length of the stripe in bytes.
getLength() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Writer
 
getLengths() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns an array containing the lengths of the files in the split.
getLikeTableName() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
getLimit() - Static method in class org.apache.hadoop.hive.ql.plan.ColumnStatsWork
 
getLimit() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getLimit() - Method in class org.apache.hadoop.hive.ql.plan.LimitDesc
 
getLimitProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory
 
getLimitRule() - Static method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory
 
getLimitTraitSet(RelOptCluster, RelTraitSet, RelNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.TraitsUtil
 
getLIMProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getLineageCtx() - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcCtx
Gets the lineage context.
getLineageInfo() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Gets the lineage information.
getLineageInfo() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
Gets the associated lineage information.
getLineageInfo() - Method in class org.apache.hadoop.hive.ql.QueryPlan
Gets the lineage information.
getLineageInfo() - Method in class org.apache.hadoop.hive.ql.session.LineageState
Gets the lineage information.
getLineageInfo(String) - Method in class org.apache.hadoop.hive.ql.tools.LineageInfo
parses given query and gets the lineage info.
getLineageState() - Method in class org.apache.hadoop.hive.ql.session.SessionState
Get the lineage state stored in this session.
getLineDelim() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getLineDelim() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getLinfo() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getLinkedFileDescTasks() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getLinkedFileSinkDesc() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getList(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveArrayInspector
 
getListBucketingCtx() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
getListBucketingCtx() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
getListElement(Object, int) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveArrayInspector
 
getListElementObjectInspector() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveArrayInspector
 
getListGroupByOperatorsProcessed() - Method in class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.GroupByOptimizerContext
 
getListGroupingSets() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getListLength(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveArrayInspector
 
getListMapJoinOpsNoReducer() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getListMapJoinsNoRed() - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
getListRejectedMapJoins() - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
getListTasks() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
getListTasks() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
getListTopOperators() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
getListWorks() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalWork
 
getLiteral() - Method in interface org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf
Get the literal half of the predicate leaf.
getLiteralList() - Method in interface org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf
For operators with multiple literals (IN and BETWEEN), get the literals.
getLLFuncExprsInTopExpr(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.parse.LeadLagInfo
 
getLlInfo() - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
getLLocalDirectoryDesc() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getLoader(Configuration) - Static method in class org.apache.hadoop.hive.ql.HashTableLoaderFactory
 
getLoadFileDesc() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
getLoadFileWork() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getLoadFileWork() - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
getLoadMultiFilesWork() - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
getLoadTableDesc() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
getLoadTableOutputMap() - Method in class org.apache.hadoop.hive.ql.Context
 
getLoadTableWork() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getLoadTableWork() - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
getLocalizedResources() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
getLocalMapRedErrors() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getLocalScratchDir(boolean) - Method in class org.apache.hadoop.hive.ql.Context
Create a local scratch directory on demand and return it.
getLocalTmpDir() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
getLocalTmpPath() - Method in class org.apache.hadoop.hive.ql.Context
Get a tmp path on local host to store intermediate data.
getLocalWork() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
getLocalWork() - Method in class org.apache.hadoop.hive.ql.plan.SMBJoinDesc
 
getLocation() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
Get the location of the entity.
getLocation() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getLocation() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
getLocation() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getLocation() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getLocation() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
getLocation() - Method in class org.apache.hadoop.hive.ql.plan.RenamePartitionDesc
 
getLocationForExplain() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getLocations() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getLocations() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns all the Paths where this input-split resides.
getLocations() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
getLocations() - Method in class org.apache.hadoop.hive.ql.io.NullRowsInputFormat.DummyInputSplit
 
getLocationUri() - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
getLockDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getLockManager() - Method in class org.apache.hadoop.hive.ql.lockmgr.DbTxnManager
 
getLockManager() - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveTxnManager
Get the lock manager.
getLockMode() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
getLocks(boolean, boolean) - Method in class org.apache.hadoop.hive.ql.lockmgr.DbLockManager
 
getLocks(HiveLockObject, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.lockmgr.DbLockManager
 
getLocks() - Method in class org.apache.hadoop.hive.ql.lockmgr.DbLockManager
 
getLocks(boolean, boolean) - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
getLocks(HiveLockObject, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
getLocks(boolean, boolean, HiveConf) - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
getLocks(HiveLockObject, boolean, boolean, HiveConf) - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
getLocks(boolean, boolean) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
getLocks(HiveLockObject, boolean, boolean) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
getLocks(boolean, boolean) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
getLocks(HiveLockObject, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
getLockTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getLockTime() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
getLongValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
getLongValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
getLongValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
getLongValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
getLongValue(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
getLVFProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getLVJProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getMacroName() - Method in class org.apache.hadoop.hive.ql.plan.CreateMacroDesc
 
getMacroName() - Method in class org.apache.hadoop.hive.ql.plan.DropMacroDesc
 
getMacroName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
getMajor() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.Version
Get the major version number.
getMap(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
getMapAliases() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getMapCurrCtx() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getMapJoinBigTableAlias() - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
getMapJoinContext() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getMapJoinDefault() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
getMapJoinFS() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
getMapJoinKeyTableDesc(Configuration, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor for Map-side join key.
getMapJoinProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
The Factory method to get ColumnMapJoinProc class.
getMapJoinTables() - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
getMapJoinValueTableDesc(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor for Map-side join value.
getMapKeyDelim() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getMapKeyDelim() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getMapKeyObjectInspector() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
getMapLocalWork() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getMapOfProjIndxToLeafPInfo() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinPredicateInfo
 
getMapOnlySubq(int) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
getMapperClass() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
getMapperClass() - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanWork
 
getMapperClass() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
getMapRedUnion() - Static method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory
 
getMapRedWork(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getMapRedWork(ParseContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
create a new plan and return.
getMapRedWork() - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
getMapRedWorkFromConf(HiveConf) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
create a new plan and return.
getMapSize(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
getMapUnion() - Static method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory
 
getMapValueElement(Object, Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.DeepParquetHiveMapInspector
 
getMapValueElement(Object, Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.StandardParquetHiveMapInspector
 
getMapValueObjectInspector() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
getMapWork(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getMapWork() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
getMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.DateColumnStatistics
Get the maximum value for the column.
getMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.DecimalColumnStatistics
Get the maximum value for the column.
getMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.DoubleColumnStatistics
Get the largest value in the column.
getMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.IntegerColumnStatistics
Get the largest value in the column.
getMaximum() - Method in interface org.apache.hadoop.hive.ql.io.orc.StringColumnStatistics
Get the maximum string.
getMaximumTime() - Method in class org.apache.hadoop.hive.ql.plan.ReducerTimeStatsPerJob
 
getMaximumTransactionId() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
getMaxOffset() - Method in class org.apache.hadoop.hive.ql.io.orc.Reader.Options
 
getMaxPartitionsPerNode() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getMaxPrefixLength(Configuration) - Static method in class org.apache.hadoop.hive.ql.stats.StatsFactory
 
getMaxRows() - Method in class org.apache.hadoop.hive.ql.Driver
Return the maximum number of rows returned by getResults
getMaxRows() - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
Return the maximum number of rows returned by fetch.
getMaxSplitSize() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getMaxStatsKeyPrefixLength() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getMaxStatsKeyPrefixLength() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getMaxTransaction() - Method in class org.apache.hadoop.hive.ql.io.AcidUtils.ParsedDelta
 
getMeanTime() - Method in class org.apache.hadoop.hive.ql.plan.ReducerTimeStatsPerJob
 
getMemoryThreshold() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getMergeFilesDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getMergeOutputPath(JobConf) - Static method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeOutputFormat
 
getMessage() - Method in exception org.apache.hadoop.hive.ql.parse.ParseException
 
getMetaData() - Method in class org.apache.hadoop.hive.ql.exec.persistence.AbstractMapJoinTableContainer
 
getMetaData() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer
 
getMetadata() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the metadata information like stripe level column statistics etc.
getMetadata() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Return the metadata (Text to Text map) that was written into the file.
getMetadata() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getMetaData() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getMetaData(QB) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getMetaData(QB, ReadEntity) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getMetadataFromPartitionSchema() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getMetadataKeys() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the user metadata keys.
getMetadataValue(String) - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get a user metadata value.
getMetadataValueOf(Text) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Return the metadata value associated with the given key.
getMetaHook() - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
getMetaHook() - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
 
getMethodInternal(Class<? extends T>, String, boolean, List<TypeInfo>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
This method is shared between UDFRegistry and UDAFRegistry.
getMethodInternal(Class<?>, List<Method>, boolean, List<TypeInfo>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Gets the closest matching method corresponding to the argument list from a list of methods.
getMethods() - Method in exception org.apache.hadoop.hive.ql.exec.UDFArgumentException
 
getMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.DateColumnStatistics
Get the minimum value for the column.
getMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.DecimalColumnStatistics
Get the minimum value for the column.
getMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.DoubleColumnStatistics
Get the smallest value in the column.
getMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.IntegerColumnStatistics
Get the smallest value in the column.
getMinimum() - Method in interface org.apache.hadoop.hive.ql.io.orc.StringColumnStatistics
Get the minimum string.
getMinimumTime() - Method in class org.apache.hadoop.hive.ql.plan.ReducerTimeStatsPerJob
 
getMinimumTransactionId() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
getMinor() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.Version
Get the minor version number.
getMinSplitSize() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
getMinSplitSize() - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanWork
 
getMinSplitSize() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
getMinSplitSize() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getMinSplitSizePerNode() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getMinSplitSizePerRack() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getMinTransaction() - Method in class org.apache.hadoop.hive.ql.io.AcidUtils.ParsedDelta
 
getMode() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObj
 
getMode() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getMode() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getMode() - Method in class org.apache.hadoop.hive.ql.plan.LockDatabaseDesc
 
getMode() - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
getMode() - Method in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeScope
 
getModeString() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getMRScratchDir() - Method in class org.apache.hadoop.hive.ql.Context
Create a map-reduce scratch directory on demand and return it.
getMRTasks(List<Task<? extends Serializable>>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getMRTmpPath() - Method in class org.apache.hadoop.hive.ql.Context
Get a path to store map-reduce intermediate data in.
getMSC() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getMsckDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getMsg(ASTNode) - Method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
getMsg(Tree) - Method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
getMsg(ASTNode, String) - Method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
getMsg(Tree, String) - Method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
getMsg(String) - Method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
getMsg() - Method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
getMultiGroupByProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory
 
getMultiParentRule() - Static method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory
 
getMvTask() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.ArchiveUtils.PartSpecInfo
Generates name for prefix partial partition specification.
getName() - Method in class org.apache.hadoop.hive.ql.exec.ColumnStatsTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.CopyTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.DDLTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.DependencyCollectionTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.ExtractOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.FilterOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.ForwardOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.FunctionTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.HashTableDummyOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
Implements the getName function for the Node Interface.
getName() - Method in class org.apache.hadoop.hive.ql.exec.LateralViewForwardOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.LateralViewJoinOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
Implements the getName function for the Node Interface.
getName() - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.MoveTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.MuxOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.Operator
Implements the getName function for the Node Interface.
getName() - Method in class org.apache.hadoop.hive.ql.exec.PTFOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
Implements the getName function for the Node Interface.
getName() - Method in class org.apache.hadoop.hive.ql.exec.StatsNoJobTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.StatsTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
The operator name for this operator type.
getName() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.UnionOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
getName() - Method in enum org.apache.hadoop.hive.ql.index.HiveIndex.IndexType
 
getName() - Method in class org.apache.hadoop.hive.ql.index.IndexMetadataChangeTask
 
getName() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.Version
Get the human readable name for the version.
getName() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.BlockMergeTask
 
getName() - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanTask
 
getName() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateTask
 
getName() - Method in interface org.apache.hadoop.hive.ql.lib.Node
Gets the name of the node.
getName() - Method in interface org.apache.hadoop.hive.ql.lib.Rule
 
getName() - Method in class org.apache.hadoop.hive.ql.lib.RuleExactMatch
 
getName() - Method in class org.apache.hadoop.hive.ql.lib.RuleRegExp
 
getName() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObj
 
getName() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
getName() - Method in class org.apache.hadoop.hive.ql.metadata.DummyPartition
 
getName() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getName() - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
getName() - Method in class org.apache.hadoop.hive.ql.parse.ASTNode
 
getName() - Method in class org.apache.hadoop.hive.ql.parse.InputSignature
 
getName() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
getName() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFunctionSpec
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.PrincipalDesc
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.TezWork.Dependency
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.TezWork
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.UnionWork
 
getName() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrincipal
 
getName() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilege
 
getName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFromUtcTimestamp
 
getName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToUtcTimestamp
 
getNamed() - Method in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
getNameMessage(Exception) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getNames() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.BucketCol
 
getNames() - Method in interface org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.BucketSortCol
 
getNames() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.SortCol
 
getNameToSample() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getNameToSplitSample() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getNameToSplitSample() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getNeededColumnIDs() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
getNeededColumns() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
getNeedLock() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getNeedsTagging() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorAggregateExpression
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFAvgDecimal
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCount
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCountStar
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFSumDecimal
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDecimal
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluatorDouble
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Get a new aggregation object.
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEWAHBitmap.GenericUDAFEWAHBitmapEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFFirstValue.GenericUDAFFirstValueEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLastValue.GenericUDAFLastValueEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMkCollectionEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFNTile.GenericUDAFNTileEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank.GenericUDAFRankEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRowNumber.GenericUDAFRowNumberEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumDouble
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumHiveDecimal
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumLong
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance.GenericUDAFVarianceEvaluator
 
getNewColComment() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNewColName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNewCols() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNewColsString() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNewColType() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNewConverter(Class<?>, int, HiveGroupConverter) - Static method in enum org.apache.hadoop.hive.ql.io.parquet.convert.ETypeConverter
 
getNewDependencyType(LineageInfo.DependencyType, LineageInfo.DependencyType) - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx
Gets the new dependency type by comparing the old dependency type and the current dependency type.
getNewKey(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.KeyWrapper
 
getNewKey(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
getNewLocation() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNewName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNewParentIndexToOldParentIndex() - Method in class org.apache.hadoop.hive.ql.plan.MuxDesc
 
getNewPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.RenamePartitionDesc
 
getNewQueryGroupbySchemaProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndex
 
getNewQuerySelectSchemaProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndex
 
getNewTagToChildIndex() - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.IntraQueryCorrelation
 
getNewTagToChildIndex() - Method in class org.apache.hadoop.hive.ql.plan.DemuxDesc
 
getNewTagToOldTag() - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.IntraQueryCorrelation
 
getNewTagToOldTag() - Method in class org.apache.hadoop.hive.ql.plan.DemuxDesc
 
getNewToOldExprMap() - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
getNextBlockStart() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
getNextRow() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
Get the next row.
getNextTag() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getNGrams() - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Returns the final top-k n-grams in a format suitable for returning to Hive.
getNonEquiJoinPredicateElements() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinPredicateInfo
 
getNonFinalCandidates() - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Returns list of non-final candidate predicate for each map.
getNoOpHiveHistoryProxy() - Static method in class org.apache.hadoop.hive.ql.history.HiveHistoryProxyHandler
 
getNoopTableFunction() - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getNoOuterJoin() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getNoOuterJoin() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getNoSemiJoin() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getNoSkewTask() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx
 
getNoStatsAggregator() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
getNotDeniedPartns() - Method in class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
 
getNoUnion() - Static method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory
 
getNthAncestor(Stack<Node>, int) - Static method in class org.apache.hadoop.hive.ql.lib.Utils
Gets the nth ancestor (the parent being the 1st ancestor) in the traversal path.
getNullExprProcessor() - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get NullExprProcessor.
getNullFormat() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getNullSafes() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getNullSafes() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getNullSafeString() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getNumberBuckets() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNumberOfRows() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the number of rows in the file.
getNumberOfRows() - Method in interface org.apache.hadoop.hive.ql.io.orc.StripeInformation
Get the number of rows in the stripe.
getNumberOfRows() - Method in interface org.apache.hadoop.hive.ql.io.orc.Writer
Return the number of rows in file.
getNumberOfValues() - Method in interface org.apache.hadoop.hive.ql.io.orc.ColumnStatistics
Get the number of values in this column.
getNumberRows() - Method in class org.apache.hadoop.hive.ql.io.RCFile.KeyBuffer
 
getNumBins() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
 
getnumBitVectors() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
getNumBuckets() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getNumBuckets() - Method in class org.apache.hadoop.hive.ql.optimizer.TezBucketJoinProcCtx
 
getNumBuckets() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
getNumBuckets() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getNumBuckets() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getNumBuckets() - Method in class org.apache.hadoop.hive.ql.plan.OpTraits
 
getNumBuckets() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getNumBuckets() - Method in class org.apache.hadoop.hive.ql.plan.TezEdgeProperty
 
getNumBucketsExplain() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getNumChild() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getNumDays() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
getNumDestinationConsumerTasks(int, int) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionEdge
 
getNumDestinationTaskPhysicalInputs(int, int) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionEdge
 
getNumDistributionKeys() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getNumDPCols() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getNumerator() - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Gets the numerator.
getNumerator() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc.sampleDesc
 
getNumExprProcessor() - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get NumExprProcessor.
getNumFalses() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
getNumFields() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcStruct
 
getNumFiles() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getNumGbys() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getNumInputs() - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
getNumInputs() - Method in class org.apache.hadoop.hive.ql.plan.UnionDesc
 
getNumJoins() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getNumMap() - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
getNumMapTasks() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getNumNulls() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
getNumOfCorrelationExprsAddedToSQSelect() - Method in class org.apache.hadoop.hive.ql.parse.QBSubQuery
 
getNumParent() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getNumPaths() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns the number of Paths in the split.
getNumReduce() - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
getNumReducers() - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.IntraQueryCorrelation
 
getNumReducers() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
Returns the number of reducers for the map-reduce job.
getNumReduceTasks() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
If the number of reducers is -1, the runtime will automatically figure it out by input data size.
getNumRows() - Method in class org.apache.hadoop.hive.ql.exec.ListSinkOperator
 
getNumRows() - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
getNumRows(Table) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get number of rows of a give table
getNumSelColumns() - Method in class org.apache.hadoop.hive.ql.plan.LateralViewJoinDesc
 
getNumSelDi() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getNumSels() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getNumSourceTaskPhysicalOutputs(int, int) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionEdge
 
getNumSPCols() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getNumSplits() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getNumTrues() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
getObj() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObj
 
getObject() - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
getObject() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeInfo
 
getObjectDefinition() - Method in class org.apache.hadoop.hive.ql.parse.ASTNodeOrigin
 
getObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
getObjectInspector() - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriter
 
getObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedColumnarSerDe
 
getObjectInspector() - Method in interface org.apache.hadoop.hive.ql.io.AcidInputFormat.RawReader
 
getObjectInspector() - Method in interface org.apache.hadoop.hive.ql.io.AcidInputFormat.RowReader
 
getObjectInspector() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRawRecordMerger
 
getObjectInspector() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSerde
 
getObjectInspector() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the object inspector for looking at the objects.
getObjectInspector() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe
 
getObjectInspectorsFromEvaluators(List<ExprNodeEvaluator>[], ObjectInspector[], int, int) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
getObjectName() - Method in class org.apache.hadoop.hive.ql.parse.ASTNodeOrigin
 
getObjectType() - Method in class org.apache.hadoop.hive.ql.parse.ASTNodeOrigin
 
getObsolete() - Method in interface org.apache.hadoop.hive.ql.io.AcidUtils.Directory
Get the list of obsolete directories.
getOffset(int) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns the start offset of the ith Path.
getOffset() - Method in class org.apache.hadoop.hive.ql.io.orc.Reader.Options
 
getOffset() - Method in interface org.apache.hadoop.hive.ql.io.orc.StripeInformation
Get the byte offset of the start of the stripe.
getOI() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFExpressionDef
 
getOI() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
getOI() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ValueBoundaryDef
 
getOldColName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getOldName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getOldPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.RenamePartitionDesc
 
getOp() - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
getOp() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getOp() - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
getOpc() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
getOpcode() - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
getOpenSessions() - Static method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
Get all open sessions.
getOperation() - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getOperationName() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getOperationName() - Method in enum org.apache.hadoop.hive.ql.plan.HiveOperation
 
getOperationName() - Method in enum org.apache.hadoop.hive.ql.plan.RoleDDLDesc.RoleOperation
 
getOperationTypes() - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.Operation2Privilege
 
getOperator() - Method in interface org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf
Get the operator for the leaf.
getOperator() - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpWalkerCtx.OpToDeleteInfo
 
getOperator() - Method in class org.apache.hadoop.hive.ql.parse.QBSubQuery
 
getOperatorId() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.ExtractOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.FilterOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.ForwardOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.HashTableDummyOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.LateralViewForwardOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.LateralViewJoinOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.MuxOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.Operator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.PTFOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.UnionOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorFilterOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator
 
getOperatorName() - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator
 
getOperatorToTableAccessMap() - Method in class org.apache.hadoop.hive.ql.parse.TableAccessInfo
 
getOpParseCtx() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getOpParseCtxMap() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getOpTaskMap() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getOptiqOperator(GenericUDF) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.translator.SqlFunctionConverter
 
getOpToParseCtxMap() - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
 
getOpToPartList() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getOpToPartPruner() - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.OpWalkerCtx
 
getOpToPartPruner() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getOpToPartToLBPruner() - Method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBOpWalkerCtx
 
getOpToPartToSkewedPruner() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getOpToRemove() - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpWalkerCtx
 
getOpToSamplePruner() - Method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner.SamplePrunerCtx
 
getOpToSamplePruner() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getOpTraits() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getOpTraits() - Method in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
getOpTraits() - Method in interface org.apache.hadoop.hive.ql.plan.OperatorDesc
 
getOpTreeSkel(Operator<?>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getOrcOptions() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater.OrcOptions
 
getOrder() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderExpression
 
getOrder() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
getOrder() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowSpec
 
getOrder() - Method in class org.apache.hadoop.hive.ql.plan.ptf.OrderExpressionDef
 
getOrder() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
getOrder() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
Returns the sort order of the key columns.
getOrderByForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getOrderSpec() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitioningSpec
 
getOrdinal(int) - Static method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils
Return an ordinal from an integer.
getOrigin() - Method in class org.apache.hadoop.hive.ql.parse.ASTNode
 
getOriginalFiles() - Method in interface org.apache.hadoop.hive.ql.io.AcidUtils.Directory
Get the list of original files.
getOrReplace() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getOuputVectorizationContext() - Method in interface org.apache.hadoop.hive.ql.exec.vector.VectorizationContextRegion
 
getOuputVectorizationContext() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator
 
getOuputVectorizationContext() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator
 
getOuputVectorizationContext() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSMBMapJoinOperator
 
getOuterJoinCount() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
getOuterQueryExpression() - Method in class org.apache.hadoop.hive.ql.parse.QBSubQuery
 
getOuterQueryId() - Method in class org.apache.hadoop.hive.ql.parse.QBSubQuery
 
getOuterQueryId() - Method in interface org.apache.hadoop.hive.ql.parse.SubQueryUtils.ISubQueryJoinInfo
 
getOuterQueryLimit() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getOutExpr(ExprNodeGenericFuncDesc, Object[]) - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory
 
getOutput(String) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezContext
 
getOutputCol() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToString
 
getOutputCol() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRand
 
getOutputCol() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRandNoSeed
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToDecimal
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToDate
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDate
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDecimal
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColAndCol
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColOrCol
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalColumnInList
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalToStringUnaryUDF
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DoubleColumnInList
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColAndScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColOrScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDecimalColumnInList
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDoubleColumnInList
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterExprAndExpr
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterExprOrExpr
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterLongColumnInList
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarAndColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarOrColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStringColumnInList
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDoubleToDecimal
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToDecimal
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToString
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRand
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRandNoSeed
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRoundWithNumDigitsDecimalToDecimal
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IdentityExpression
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNotNull
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNull
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColumnInList
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarDivideLongColumn
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongToStringUnaryUDF
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncDoubleToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToDouble
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NotCol
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsFalse
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNotNull
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNull
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsTrue
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringColumnInList
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColCol
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatScalarCol
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringLength
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStart
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStartLen
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDF
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDFDirect
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorCoalesce
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression
Returns the index of the output column in the array of column vectors.
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColCol
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldString
 
getOutputColumn() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
getOutputColumnLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getOutputColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getOutputColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getOutputColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getOutputColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.SelectDesc
 
getOutputColumnNames() - Method in class org.apache.hadoop.hive.ql.udf.ptf.Noop.NoopResolver
 
getOutputColumnNames() - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMap.NoopWithMapResolver
 
getOutputColumnNames() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
 
getOutputColumnNames() - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.WindowingTableFunctionResolver
 
getOutputColumnTypeMap() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
getOutputDBLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getOutputDir() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
getOutputDir() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
getOutputDir() - Method in class org.apache.hadoop.hive.ql.parse.AlterTablePartMergeFilesDesc
 
getOutputDir() - Method in class org.apache.hadoop.hive.ql.plan.TruncateTableDesc
 
getOutputFileFormatClass() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getOutputFileFormatClass() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getOutputFileFormatClassName() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getOutputFileFormatClassName() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getOutputFormat() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
getOutputFormat() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getOutputFormat() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getOutputFormat() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getOutputFormatClass() - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
getOutputFormatClass() - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
 
getOutputFormatClass() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getOutputFormatClass() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getOutputFormatFinalPath(Path, String, JobConf, HiveOutputFormat<?, ?>, boolean, Path) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
Deprecated.  
getOutputFormatSubstitute(Class<?>, boolean) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
get a OutputFormat's substitute HiveOutputFormat.
getOutputInternalColNames() - Method in class org.apache.hadoop.hive.ql.plan.LateralViewJoinDesc
 
getOutputKeyColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getOutputLockObjects() - Method in class org.apache.hadoop.hive.ql.Context
 
getOutputName() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
returns output ObjectInspector, never null
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorAggregateExpression
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFAvgDecimal
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCount
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCountStar
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFSumDecimal
 
getOutputObjInspector() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getOutputOI() - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
Return initialized ObjectInspector.
getOutputOI() - Method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
getOutputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
getOutputPrivs(HiveOperationType) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.Operation2Privilege
 
getOutputRequiredPrivileges() - Method in enum org.apache.hadoop.hive.ql.plan.HiveOperation
 
getOutputs() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getOutputs() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
Get the output set.
getOutputs() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getOutputs() - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContext
 
getOutputs() - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
getOutputs() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getOutputs() - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
getOutputs() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getOutputShape() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFInputDef
 
getOutputTableLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getOutputTableList() - Method in class org.apache.hadoop.hive.ql.tools.LineageInfo
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToDate
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDate
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColAndCol
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColOrCol
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalColumnInList
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalToStringUnaryUDF
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DoubleColumnInList
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColAndScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColOrScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDecimalColumnInList
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDoubleColumnInList
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterExprAndExpr
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterExprOrExpr
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterLongColumnInList
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarAndColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarOrColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStringColumnInList
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToString
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRand
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRandNoSeed
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRoundWithNumDigitsDecimalToDecimal
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IdentityExpression
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNotNull
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNull
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColumnInList
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarDivideLongColumn
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongToStringUnaryUDF
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncDoubleToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToDouble
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NotCol
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsFalse
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNotNull
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNull
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsTrue
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringColumnInList
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColCol
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatScalarCol
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringLength
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStart
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStartLen
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDF
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDFDirect
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorCoalesce
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression
Returns type of the output column.
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColCol
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldString
 
getOutputType() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
getOutputUserLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getOutputValueColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getOutRecordReaderClass() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getOutStream() - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
getOutWriters() - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
 
getOverlayedProperties() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getOverriddenConfigurations() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getOwner() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getOwnerPrincipal() - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
getP() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
getParameterObjectInspectors() - Method in interface org.apache.hadoop.hive.ql.udf.generic.GenericUDAFParameterInfo
 
getParameterObjectInspectors() - Method in class org.apache.hadoop.hive.ql.udf.generic.SimpleGenericUDAFParameterInfo
 
getParameters() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
Get the parameter map of the Entity.
getParameters() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getParameters() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getParameters() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getParameters() - Method in interface org.apache.hadoop.hive.ql.udf.generic.GenericUDAFParameterInfo
Deprecated. 
getParameters() - Method in class org.apache.hadoop.hive.ql.udf.generic.SimpleGenericUDAFParameterInfo
Deprecated. 
getParent() - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpWalkerCtx.OpToDeleteInfo
 
getParentDir() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getParentOperators() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getParents() - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
getParents(BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
getParents returns all the nodes with edges leading into work
getParentTasks() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getParentToInput() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getParentToKeyCols() - Method in class org.apache.hadoop.hive.ql.plan.MuxDesc
 
getParentToOutputKeyColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.MuxDesc
 
getParentToOutputValueColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.MuxDesc
 
getParentToTag() - Method in class org.apache.hadoop.hive.ql.plan.MuxDesc
 
getParentToValueCols() - Method in class org.apache.hadoop.hive.ql.plan.MuxDesc
 
getParentViewInfo(String, Map<String, ReadEntity>) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
getParitionColsString() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBOpPartitionWalkerCtx
Return parse context.
getParseContext() - Method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.AnnotateOpTraitsProcCtx
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpWalkerCtx
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.index.IndexWhereProcCtx
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.AnnotateStatsProcCtx
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext
 
getParseContext(ParseContext, List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.parse.MapReduceCompiler
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getParseContext(ParseContext, List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.parse.TaskCompiler
Create a clone of the parse context
getParseContext() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
getParseCtx() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getParseCtx() - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx
Gets the parse context.
getParseCtx() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
getParseCtx() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinResolver.SkewJoinProcCtx
 
getParseInfo() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getParseTree() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getPart() - Method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBExprProcCtx
 
getPart() - Method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBOpWalkerCtx
 
getPartColNames() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getPartCols() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getPartCols() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getPartCols() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getPartColsString() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getPartColsString() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getPartColumns() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getPartColumnStats(Table, List<ColumnInfo>, List<String>, List<String>) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get table level column statistics from metastore for needed columns
getPartDesc() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getPartDescOrderedByPartDir() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
Get Partition descriptors in sorted (ascending) order of partition directory
getPartDescs(List<Path>) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getPartDir() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getPartialName(Partition, int) - Static method in class org.apache.hadoop.hive.ql.exec.ArchiveUtils
Get a prefix of the given parition's string representation.
getPartition(HiveKey, Object, int) - Method in class org.apache.hadoop.hive.ql.exec.HiveTotalOrderPartitioner
 
getPartition() - Method in interface org.apache.hadoop.hive.ql.exec.PTFPartition.PTFPartitionIterator
 
getPartition() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
Get the partition associated with the entity.
getPartition() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DataContainer
 
getPartition(Table, Map<String, String>, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getPartition(Table, Map<String, String>, boolean, String, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns partition metadata
getPartition() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
getPartition() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowSpec
 
getPartition(int) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getPartition() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
getPartitionCols() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getPartitionCols() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getPartitionColumnStatistics(String, String, List<String>, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getPartitionCount() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getPartitionDesc(Partition) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getPartitionDescFromPathRecursively(Map<String, PartitionDesc>, Path, Map<Map<String, PartitionDesc>, Map<String, PartitionDesc>>) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
 
getPartitionDescFromPathRecursively(Map<String, PartitionDesc>, Path, Map<Map<String, PartitionDesc>, Map<String, PartitionDesc>>, boolean) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
 
getPartitionDescFromTableDesc(TableDesc, Partition) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getPartitionDescMap() - Method in class org.apache.hadoop.hive.ql.io.IOPrepareCache
 
getPartitionDescs() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getPartitionEval() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator
 
getPartitionInformation(Partition) - Static method in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatUtils
 
getPartitioning() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
getPartitioning() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowSpec
 
getPartitionKeys() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getPartitionName() - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult.PartitionResult
 
getPartitionNames(String, short) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getPartitionNames(String, String, short) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getPartitionNames(String, String, Map<String, String>, short) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getPartitions(Table) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
get all the partitions that the table has
getPartitions(Table, Map<String, String>, short) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
get all the partitions of the table that matches the given partial specification.
getPartitions(Table, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
get all the partitions of the table that matches the given partial specification.
getPartitions() - Method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBOpPartitionWalkerCtx
Return partitions.
getPartitions() - Method in class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
 
getPartitionsByExpr(Table, ExprNodeGenericFuncDesc, HiveConf, List<Partition>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get a list of Partitions by expr.
getPartitionsByFilter(Table, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get a list of Partitions by filter.
getPartitionsByNames(Table, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
get all the partitions of the table that matches the given partial specification.
getPartitionsByNames(Table, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get all partitions of the table that matches the list of given partition names.
getPartitionsNotInMs() - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult
 
getPartitionsNotOnFs() - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult
 
getPartitionSpec() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getPartitionSpecs() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableExchangePartition
 
getPartKeySpec() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableAlterPartDesc
 
getPartList() - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcCtx
 
getPartName() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getPartName() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
getPartParams() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.index.IndexMetadataChangeWork
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.parse.AlterTablePartMergeFilesDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
getPartSpec(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.DDLSemanticAnalyzer
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitioningSpec
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc.PartSpec
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.TruncateTableDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.UnlockTableDesc
 
getPartSpecForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getPartSpecs() - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
getPartSpecs() - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
getPartSpecStringForExplain() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getPath() - Method in class org.apache.hadoop.hive.ql.io.AcidUtils.ParsedDelta
 
getPath() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getPath(int) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns the ith Path.
getPath() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
getPath() - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock
 
getPath() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getPath(Sample) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getPath() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getPaths(List<AcidUtils.ParsedDelta>) - Static method in class org.apache.hadoop.hive.ql.io.AcidUtils
Convert a list of deltas to a list of delta directories.
getPaths() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns all the Paths in the split.
getPaths() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
getPaths() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getPathToAliases() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
getPathToAliases() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getPathToCS() - Method in class org.apache.hadoop.hive.ql.Context
 
getPathToPartitionInfo() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getPattern() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar
 
getPattern() - Method in class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
getPattern() - Method in class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
getPattern() - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
getPattern() - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
getPctx() - Method in class org.apache.hadoop.hive.ql.optimizer.Optimizer
 
getPctx() - Method in class org.apache.hadoop.hive.ql.optimizer.PreCBOOptimizer
 
getPercent() - Method in class org.apache.hadoop.hive.ql.parse.SplitSample
 
getPerfLogger() - Static method in class org.apache.hadoop.hive.ql.log.PerfLogger
 
getPerfLogger(boolean) - Static method in class org.apache.hadoop.hive.ql.log.PerfLogger
Call this function to get an instance of PerfLogger.
getPerfLogger(boolean) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getpGraphContext() - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
getpGraphContext() - Method in class org.apache.hadoop.hive.ql.optimizer.SkewJoinOptimizer.SkewJoinOptProcCtx
 
getpItr() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
getPlan() - Method in class org.apache.hadoop.hive.ql.Driver
 
getPlanPath(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.avro.AvroGenericRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.NullRowsInputFormat.NullRowsRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.OneNullRowInputFormat.OneNullRowRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRawRecordMerger
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.parquet.read.ParquetRecordReaderWrapper
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
getPosBigTable() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getPosBigTable() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getPosition() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Returns the current position in the input.
getPosition() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Return the current byte position in the input file.
getPosition(String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getPosition() - Method in class org.apache.hadoop.hive.ql.plan.ExplosionDesc
 
getPositionParent(AbstractMapJoinOperator<? extends MapJoinDesc>, Stack<Node>) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory
 
getPositionParent(UnionOperator, Stack<Node>) - Static method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory
 
getPostJoinFilters() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getPosToAliasMap() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
getPower() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerDoubleToDouble
 
getPower() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerLongToDouble
 
getPredicate() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
getPredicateColumnsList() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getPredicateString() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
getPrefixedTaskIdFromFilename(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Get the part-spec + task id from the filename.
getPrefixLength() - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc.PartSpec
 
getPreserved() - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
getPreserved() - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetByteInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetShortInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetStringInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetByteInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetShortInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetStringInspector
 
getPrincipal() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeInfo
 
getPrincipalDesc(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.authorization.AuthorizationParseUtils
 
getPrincipalDesc() - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
getPrincipalDesc() - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
getPrincipalGrantInfoForRole(String) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessController
 
getPrincipalGrantInfoForRole(String) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
Get the grant information for principals granted the given role
getPrincipalGrantInfoForRole(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
getPrincipalGrantInfoForRole(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
getPrincipalName() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
getPrincipals() - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
getPrincipals() - Method in class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
getPrincipalType() - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getPrincipalType() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
getPriv() - Method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
getPrivilege() - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeDesc
 
getPrivilege() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeInfo
 
getPrivilege(PrivilegeType) - Static method in class org.apache.hadoop.hive.ql.security.authorization.PrivilegeRegistry
 
getPrivilege(int) - Static method in class org.apache.hadoop.hive.ql.security.authorization.PrivilegeRegistry
 
getPrivilege(String) - Static method in class org.apache.hadoop.hive.ql.security.authorization.PrivilegeRegistry
 
getPrivileges() - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
getPrivileges() - Method in class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
getPrivilegesFromFS(Path, HiveConf, String) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLAuthorizationUtils
Map permissions for this uri to SQL Standard privileges
getPrivilegeSubjectDesc() - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
getPrivilegeSubjectDesc() - Method in class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
getPrivType() - Method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLPrivTypeGrant
 
getPrivTypeByName(String) - Static method in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeType
Do case insensitive lookup of PrivilegeType with this name
getPrivTypeByToken(int) - Static method in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeType
Do case lookup of PrivilegeType associated with this antlr token
getProgress() - Method in class org.apache.hadoop.hive.ql.io.avro.AvroGenericRecordReader
 
getProgress() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
getProgress() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveRecordReader
 
getProgress() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
 
getProgress() - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
getProgress() - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
getProgress() - Method in class org.apache.hadoop.hive.ql.io.NullRowsInputFormat.NullRowsRecordReader
 
getProgress() - Method in class org.apache.hadoop.hive.ql.io.OneNullRowInputFormat.OneNullRowRecordReader
 
getProgress() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRawRecordMerger
 
getProgress() - Method in interface org.apache.hadoop.hive.ql.io.orc.RecordReader
Get the progress of the reader through the rows.
getProgress() - Method in class org.apache.hadoop.hive.ql.io.parquet.read.ParquetRecordReaderWrapper
 
getProgress() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeRecordReader
Return the progress within the input split.
getProgress() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
Return the progress within the input split.
getProgress() - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
Return the progress within the input split.
getProjsFromLeftPartOfJoinKeysInChildSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinLeafPredicateInfo
 
getProjsFromLeftPartOfJoinKeysInChildSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinPredicateInfo
 
getProjsFromLeftPartOfJoinKeysInJoinSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinLeafPredicateInfo
NOTE: Join Schema = left Schema + (right Schema offset by left.fieldcount).
getProjsFromLeftPartOfJoinKeysInJoinSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinPredicateInfo
NOTE: Join Schema = left Schema + (right Schema offset by left.fieldcount).
getProjsFromRightPartOfJoinKeysInChildSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinLeafPredicateInfo
 
getProjsFromRightPartOfJoinKeysInChildSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinPredicateInfo
 
getProjsFromRightPartOfJoinKeysInJoinSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinLeafPredicateInfo
 
getProjsFromRightPartOfJoinKeysInJoinSchema() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinPredicateInfo
 
getProperties() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getProperties() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getProperty(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getPropertyName() - Method in class org.apache.hadoop.hive.ql.plan.ShowTblPropertiesDesc
 
getPropName() - Method in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.OrcTableProperties
 
getProps() - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
getProps() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getProtectMode() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getProtectMode() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getProtectModeType() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getPrunedColList(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
 
getPrunedColLists() - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
 
getPrunedPartitions() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getPrunedPartitions(String, TableScanOperator) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getPrunedPreds(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
getPtfDesc() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
 
getPTFInvocationSpec(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getPTFNodeToSpec() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getPTFProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
Factory method to get the ColumnPrunerGroupByProc class.
getPTFProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getQB() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getQB() - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
getQB() - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getQBExpr1() - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
getQBExpr2() - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
getQbJoinTree() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getQualifiedFunctionNameParts(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionUtils
 
getQualifiedNames(String) - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getQuery() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getQueryId() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
getQueryId() - Method in class org.apache.hadoop.hive.ql.plan.LockDatabaseDesc
 
getQueryId() - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
getQueryId() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getQueryId() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getQueryInput() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec
 
getQueryInput() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
getQueryInput() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFInputSpec
 
getQueryInput() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFQueryInputSpec
 
getQueryInputName() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec
 
getQueryInputName() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
getQueryInputName() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFInputSpec
 
getQueryInputName() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFQueryInputSpec
 
getQueryOrderSpec() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec
 
getQueryPartitioningSpec() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec
 
getQueryPartitions() - Method in class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
getQueryPartitionSpec() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec
 
getQueryPlan() - Method in class org.apache.hadoop.hive.ql.Driver
 
getQueryPlan() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getQueryPlan() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getQueryPlan() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getQueryProperties() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getQueryProperties() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getQueryProperties() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getQueryStartTime() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getQueryStr() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
getQueryStr() - Method in class org.apache.hadoop.hive.ql.plan.LockDatabaseDesc
 
getQueryStr() - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
getQueryStr() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getQueryString() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getQueryTasks() - Method in class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
getQueued() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getQueueName() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
getRandom() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRand
 
getRandom() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRandNoSeed
 
getRandomWaitTime(int, int, Random) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Introducing a random factor to the wait time before another retry.
getRawDataSize() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the deserialized data size of the file
getRawDataSize() - Method in interface org.apache.hadoop.hive.ql.io.orc.Writer
Return the deserialized data size.
getRawDataSize(Table) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get raw data size of a give table
getRawDataSizeOfColumns(List<String>) - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the deserialized data size of the specified columns
getRawInputColumnNames() - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMap.NoopWithMapResolver
 
getRawInputColumnNames() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
 
getRawInputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
getRawInputShape() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
getRawReader(Configuration, boolean, int, ValidTxnList, Path, Path[]) - Method in interface org.apache.hadoop.hive.ql.io.AcidInputFormat
Get a reader that returns the raw ACID events (insert, update, delete).
getRawReader(Configuration, boolean, int, ValidTxnList, Path, Path[]) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
 
getRawRecordWriter(Path, AcidOutputFormat.Options) - Method in interface org.apache.hadoop.hive.ql.io.AcidOutputFormat
Create a raw writer for ACID events.
getRawRecordWriter(Path, AcidOutputFormat.Options) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcOutputFormat
 
getReader() - Method in class org.apache.hadoop.hive.ql.exec.tez.tools.TezMergedLogicalInput
 
getReader(InputSplit, AcidInputFormat.Options) - Method in interface org.apache.hadoop.hive.ql.io.AcidInputFormat
Get a record reader that provides the user-facing view of the data after it has been merged together.
getReader(InputSplit, AcidInputFormat.Options) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
 
getRealClass() - Method in interface org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContext
Produces the specific class to deserialize.
getRealClass() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
 
getRealOutputFormatClassName() - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
get a RealOutputFormatClassName corresponding to the HivePassThroughOutputFormat
getRecordLength() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer.PTFSequenceFileInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.avro.AvroContainerInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat
Create a generic Hive RecordReader than can iterate over all chunks in a CombinedFileSplit.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.NullRowsInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.OneNullRowInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.orc.VectorizedOrcInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.parquet.MapredParquetInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.RCFileInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileInputFormat
 
getRecordUpdater(Path, AcidOutputFormat.Options) - Method in interface org.apache.hadoop.hive.ql.io.AcidOutputFormat
Create a RecordUpdater for inserting, updating, or deleting records.
getRecordUpdater(Path, AcidOutputFormat.Options) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.ql.io.avro.AvroContainerOutputFormat
 
getRecordWriter(JobConf, HiveOutputFormat<?, ?>, Class<? extends Writable>, boolean, Properties, Path, Reporter) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.ql.io.HiveOutputFormatImpl
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.ql.io.HivePassThroughOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.ql.io.IgnoreKeyTextOutputFormat
Deprecated.  
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcNewOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.ql.io.parquet.MapredParquetOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.ql.io.RCFileOutputFormat
getReduceKeyTableDesc(List<FieldSchema>, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor for reduce key.
getReducer() - Method in class org.apache.hadoop.hive.ql.exec.mr.MapRedTask
 
getReducer() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getReducer() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getReducerTimeStatsPerJobList() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getReduceSinkDesc(ArrayList<ExprNodeDesc>, ArrayList<ExprNodeDesc>, List<String>, boolean, int, ArrayList<ExprNodeDesc>, String, int) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Create the reduce sink descriptor.
getReduceSinkDesc(ArrayList<ExprNodeDesc>, int, ArrayList<ExprNodeDesc>, List<List<Integer>>, List<String>, List<String>, boolean, int, ArrayList<ExprNodeDesc>, String, int) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Create the reduce sink descriptor.
getReduceSinkDesc(ArrayList<ExprNodeDesc>, ArrayList<ExprNodeDesc>, List<String>, boolean, int, int, int) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Create the reduce sink descriptor.
getReduceSinkDesc(ArrayList<ExprNodeDesc>, int, ArrayList<ExprNodeDesc>, List<List<Integer>>, List<String>, List<String>, boolean, int, int, int) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Create the reduce sink descriptor.
getReduceSinkOperatorsAddedByEnforceBucketingSorting() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getReduceSinkProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
The Factory method to get ColumnPrunerReduceSinkProc class.
getReduceSinkProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getReduceSinkRule() - Static method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory
 
getReduceValueTableDesc(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor for intermediate files.
getReduceWork(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getReduceWork() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
getReferenceableColumnAliases(String, int) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
Get a list of aliases for non-hidden columns
getRegistry(Configuration) - Static method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
getRejectedJoinOps() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
getRenamePartitionDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getReplace() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getReplaceTableScanProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndex
 
getReporter() - Method in class org.apache.hadoop.hive.ql.exec.MapredContext
Returns Reporter, which is set right before reading the first row.
getReporter() - Method in class org.apache.hadoop.hive.ql.io.AcidInputFormat.Options
 
getReporter() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
getRequiredFiles() - Method in class org.apache.hadoop.hive.ql.exec.UDF
 
getRequiredFiles() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
getRequiredFiles() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
getRequiredFiles() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFInFile
 
getRequiredJars() - Method in class org.apache.hadoop.hive.ql.exec.UDF
These can be overriden to provide the same functionality as the correspondingly named methods in GenericUDF.
getRequiredJars() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
The following two functions can be overridden to automatically include additional resources required by this UDF.
getRequiredJars() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
getRequiredPrivilegeSet() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.RequiredPrivileges
 
getRequirePrivilege(String) - Static method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLPrivilegeType
 
getResDir() - Method in class org.apache.hadoop.hive.ql.Context
 
getResFile() - Method in class org.apache.hadoop.hive.ql.Context
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowColumnsDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowCompactionsDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowCreateTableDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowIndexesDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowTblPropertiesDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowTxnsDesc
 
getResFileString() - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
getResFileString() - Method in class org.apache.hadoop.hive.ql.plan.ShowTblPropertiesDesc
 
getResidualPredicate() - Method in class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
getResidualPredicates(boolean) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
getResolver() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
getResolver() - Method in class org.apache.hadoop.hive.ql.exec.UDAF
Deprecated. Gets the resolver.
getResolver() - Method in class org.apache.hadoop.hive.ql.exec.UDF
Get the method resolver.
getResolverClassName() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
getResolverCtx() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
getResourceBaseName(Path) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
getResourceFiles(Configuration, SessionState.ResourceType) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getResources() - Method in class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
getResponseCode() - Method in class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
 
getResult() - Method in class org.apache.hadoop.hive.ql.exec.DummyStoreOperator
 
getResult() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
getResult() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
getResult() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance.GenericUDAFVarianceEvaluator
 
getResults(List) - Method in class org.apache.hadoop.hive.ql.Driver
 
getResultSchema() - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
getResultSchema() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getResultSchema() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getResultSchema() - Method in class org.apache.hadoop.hive.ql.parse.ExplainSemanticAnalyzer
 
getResultSchema() - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getResultType() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
getRetainList() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getRetainList() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getRetention() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getReversedExprs() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getReversedExprs() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getRevokeDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getRHSSemijoinColumns(String) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getRight() - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
getRight() - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
getRightAliases() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getRoleDDLDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getRoleGrantInfoForPrincipal(String, PrincipalType) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getRoleGrantInfoForPrincipal(HivePrincipal) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessController
 
getRoleGrantInfoForPrincipal(HivePrincipal) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
Get the grant information of roles the given principal belongs to
getRoleGrantInfoForPrincipal(HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
getRoleGrantInfoForPrincipal(HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
getRoleGrants() - Method in class org.apache.hadoop.hive.ql.session.CreateTableAutomaticGrant
 
getRoleName() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
getRoleNameSchema() - Static method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getRoleOwnerName() - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getRoles() - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
getRoleShowGrantSchema() - Static method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getRootConverter() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.DataWritableRecordConverter
 
getRootPath() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getRoots() - Method in class org.apache.hadoop.hive.ql.plan.TezWork
getRoots returns all nodes that do not have a parent.
getRootTask(int) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
getRootTasks() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getRootTasks() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
getRootTasks() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getRootTasks() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
getRootTasks() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getRowContainer(Configuration, List<ObjectInspector>, Byte, int, TableDesc[], JoinDesc, boolean, Reporter) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
getRowCount() - Method in class org.apache.hadoop.hive.ql.metadata.InputEstimator.Estimation
 
getRowCount() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.RelOptHiveTable
 
getRowCount() - Method in class org.apache.hadoop.hive.ql.parse.SplitSample
 
getRowId() - Method in class org.apache.hadoop.hive.ql.io.RecordIdentifier
What was the original row id for the last row?
getRowIndexStride() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the number of rows per a entry in the row index.
getRowLimit() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getRowLimitExplain() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getRowNumber() - Method in interface org.apache.hadoop.hive.ql.io.orc.RecordReader
Get the row number of the row that will be returned by the following call to next().
getRowResolver() - Method in class org.apache.hadoop.hive.ql.parse.OpParseContext
 
getRowResolver(Operator) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
Get the row resolver given an operator.
getRowResolver(Node) - Method in class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
getRows() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCost
 
getRows() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveAggregateRel
 
getRows() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveTableScanRel
 
getRowSchema() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getRowsComputedUsingStats() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getRowSkewedIndex() - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
getRr() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
getRslvMap() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getRunnable(int) - Method in class org.apache.hadoop.hive.ql.DriverContext
 
getRunner() - Method in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
getSampleDescr() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
getSampleDimension() - Method in class org.apache.hadoop.hive.ql.metadata.Sample
 
getSampleFraction() - Method in class org.apache.hadoop.hive.ql.metadata.Sample
 
getSampleNum() - Method in class org.apache.hadoop.hive.ql.metadata.Sample
 
getSamplingType() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getSamplingTypeString() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getSchema() - Method in class org.apache.hadoop.hive.ql.Driver
 
getSchema(BaseSemanticAnalyzer, HiveConf) - Static method in class org.apache.hadoop.hive.ql.Driver
Get a Schema with fields represented with native Hive types
getSchema() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getSchema(Configuration) - Static method in class org.apache.hadoop.hive.ql.io.parquet.write.DataWritableWriteSupport
 
getSchema() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getSchema() - Static method in class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
getSchema() - Static method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.SchemaDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowColumnsDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowCompactionsDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowCreateTableDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
getSchema() - Static method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
getSchema() - Static method in class org.apache.hadoop.hive.ql.plan.ShowIndexesDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowTblPropertiesDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowTxnsDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
 
getSchemaFromTableSchema(Properties) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getSchemaString() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getScratchColumnMap() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getScratchColumnVectorTypes() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getScriptCmd() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getScriptErrInfo() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getScriptInputInfo() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getScriptOutputInfo() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getSCRProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getSearchArgument() - Method in class org.apache.hadoop.hive.ql.io.orc.Reader.Options
 
getSecond() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.Pair
 
getSeedNum() - Method in class org.apache.hadoop.hive.ql.parse.SplitSample
 
getSeenFileSinkOps() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getSelectAggr(String, String) - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Prepares SELECT query for statistics aggregation.
getSelectColsFromChildren(SelectOperator, List<String>) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
Creates the list of internal column names for select * expressions.
getSelectColsFromLVJoin(RowResolver, List<String>) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
Create the list of internal columns for select tag of LV
getSelectColumnsList() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
getSelectivity(HiveTableScanRel, RexNode) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.stats.HiveRelMdSelectivity
 
getSelectivity(HiveJoinRel, RexNode) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.stats.HiveRelMdSelectivity
 
getSelectProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
The Factory method to get the ColumnPrunerSelectProc class.
getSelectRule() - Static method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory
 
getSelectRule() - Static method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory
 
getSelectTraitSet(RelOptCluster, List<RexNode>, RelNode) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.TraitsUtil
 
getSelForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getSelProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getSelProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory
 
getSemanticInputs() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getSerDe() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectSerDeContext
 
getSerDe() - Method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
getSerde() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getSerde() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
getSerDeClass() - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
getSerDeClass() - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
 
getSerdeClassName() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getSerdeClassName() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
getSerdeClassName() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getSerdeName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getSerdeParam(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSerdeParams() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
getSerdeProps() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getSerdeProps() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getSerdeProps() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
getSerDeStats() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedColumnarSerDe
 
getSerDeStats() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSerde
Always returns null, since serialized size doesn't make sense in the context of ORC files.
getSerDeStats() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe
 
getSerialization() - Method in interface org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContext
An Serialization object for objects of type S.
getSerialization() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
Looks up and instantiates the Serialization Object Important to note here that we are not relying on the Hadoop SerializationFactory part of the Serialization framework.
getSerializationLib() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSerializationLib() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
getSerializationNullFormat() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getSerializationNullFormat() - Method in class org.apache.hadoop.hive.ql.plan.ListSinkDesc
 
getSerializedClass() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedColumnarSerDe
 
getSerializedClass() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSerde
 
getSerializedClass() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe
 
getSerName() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getSession(TezSessionState, HiveConf, boolean) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
getSession(TezSessionState, HiveConf, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
getSession() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
getSessionId() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
getSessionId() - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryViewer
 
getSessionId() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getSettableExpressionWriters(SettableStructObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory
 
getShowColumnsDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowCompactionsDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowCreateTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowDatabasesDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowFuncsDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowGrantDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowIndexesDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowLocksDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowPartsDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowRolePrincipalsSchema() - Static method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getShowTblPropertiesDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowTblsDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowTblStatusDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowTxnsDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getSignature() - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
getSingleParent(Operator<?>, Operator<?>) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
 
getSink() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsWork
 
getSink() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getSize() - Method in class org.apache.hadoop.hive.ql.io.RCFile.KeyBuffer
get number of bytes to store the keyBuffer.
getSizeOfComplexTypes(HiveConf, ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get the size of complex data types
getSizeOfMap(StandardConstantMapObjectInspector) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Estimate the size of map object
getSizeOfPrimitiveTypeArraysFromType(String, int) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get the size of arrays of primitive types
getSkewColPosition() - Method in class org.apache.hadoop.hive.ql.plan.SkewedColumnPositionPair
 
getSkewedColNames() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getSkewedColNames() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSkewedColNames() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getSkewedColNames() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getSkewedColNames() - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
getSkewedColumnNames(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
Retrieve skewed column name for a table.
getSkewedColValueLocationMaps() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getSkewedColValueLocationMaps() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSkewedColValues() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getSkewedColValues() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSkewedColValues() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getSkewedColValues() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getSkewedColValues() - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
getSkewedInfo() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSkewedLocations() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getSkewedValuesDirNames() - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
getSkewKeyDefinition() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getSkewKeyDefinition() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getSkewKeysValuesTables() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getSkewKeysValuesTables() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getSmallKeysDirMap() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getSmallKeysDirMap() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getSmbMapJoinContext() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getSolution() - Method in class org.apache.hadoop.hive.ql.exec.errors.ErrorAndSolution
 
getSortByForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
Get the Sort By AST for the clause.
getSortColNames() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getSortCols() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getSortCols() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSortCols() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
getSortCols() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getSortColumns() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getSortedCols(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx
 
getSortedColsByDirectory() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx
 
getSortedColsByDirectory() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getSortedPaths() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
get all paths for this partition in a sorted manner
getSortedPaths() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSortOrder() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.SortCol
 
getSortTraitSet(RelOptCluster, RelTraitSet, RelCollation) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.TraitsUtil
 
getSource() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFQueryInputSpec
 
getSource() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getSourceDirs() - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
getSourceId() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowSpec
 
getSourcePath() - Method in class org.apache.hadoop.hive.ql.plan.LoadDesc
 
getSourceTable() - Method in class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
 
getSourceTable() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableExchangePartition
 
getSourceTask() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
getSPColNames() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getSpec() - Method in class org.apache.hadoop.hive.ql.metadata.DummyPartition
 
getSpec() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getSpec() - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
getSpillSerDe(byte, TableDesc[], JoinDesc, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
getSpillTableDesc(Byte, TableDesc[], JoinDesc, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
getSplit(int) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getSplitNum() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.ql.index.HiveIndexedInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat
Create Hive splits based on CombineFileSplit.
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.ql.io.NullRowsInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
 
getSplits(JobContext) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcNewInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat
Parses all target paths from job input directory which contains symlink files, and splits the target data using TextInputFormat.
getSplitSample() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getSPPath() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getSQLPrivTypeGrant(SQLPrivilegeType, boolean) - Static method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLPrivTypeGrant
Find matching enum
getSQLPrivTypeGrant(String, boolean) - Static method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLPrivTypeGrant
Find matching enum
getSQLState() - Method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
getSQLState() - Method in class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
 
getSrcForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getSrcForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getSrcs() - Method in class org.apache.hadoop.hive.ql.optimizer.SortBucketJoinProcCtx
 
getStackTraces() - Method in class org.apache.hadoop.hive.ql.exec.errors.TaskLogProcessor
Processes the provided task logs to extract stack traces.
getStackTraces() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getStageID() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getStandardDeviationTime() - Method in class org.apache.hadoop.hive.ql.plan.ReducerTimeStatsPerJob
 
getStandardObjectInspectors(List<ObjectInspector>[], int, int) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
getStandardOI() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectSerDeContext
 
getStandardStructOI(RowResolver) - Static method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
For each column on the input RR, construct a StructField for it OI is constructed using the list of input column names and their corresponding OIs.
getStart() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
The position of the first byte in the file to process.
getStart() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
The position of the first byte in the file to process.
getStart() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeRecordReader
 
getStart() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
getStart() - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
getStart() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFrameSpec
 
getStart() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFrameDef
 
getStarted() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getStartIdx() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStart
 
getStartIdx() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStartLen
 
getStartOfChain() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec
 
getStartOfChain() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
getStartOfChain() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
getStartOfChain() - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
getStartOffsets() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns an array containing the startoffsets of the files in the split.
getStartTime(String) - Method in class org.apache.hadoop.hive.ql.log.PerfLogger
 
getStat() - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
 
getStat(String) - Method in class org.apache.hadoop.hive.ql.exec.Stat
 
getStatColumnName(String) - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Returns the column where the statistics for the given type are stored.
getStaticSpec() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getStatistics() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getStatistics() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the statistics about the columns in the file.
getStatistics() - Method in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
getStatistics() - Method in interface org.apache.hadoop.hive.ql.plan.OperatorDesc
 
getStatRowOI() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getStats() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getStats() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater
 
getStats() - Method in interface org.apache.hadoop.hive.ql.io.RecordUpdater
Returns the statistics information
getStats() - Method in interface org.apache.hadoop.hive.ql.io.StatsProvidingRecordReader
Returns the statistics information
getStats() - Method in interface org.apache.hadoop.hive.ql.io.StatsProvidingRecordWriter
Returns the statistics information
getStatsAggPrefix() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
Construct the key prefix used as (intermediate) statistics publishing and aggregation.
getStatsAggPrefix() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getStatsAggregator() - Method in class org.apache.hadoop.hive.ql.stats.StatsFactory
Returns a Stats Aggregator implementation class for the IStatsAggregator interface For example HBaseStatsAggregator for the HBase implementation
getStatsPublisher(JobConf) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getStatsPublisher() - Method in class org.apache.hadoop.hive.ql.stats.StatsFactory
Returns a Stats publisher implementation class for the IStatsPublisher interface For example HBaseStatsPublisher for the HBase implementation
getStatsRegistry(Configuration) - Static method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
getStatTableName() - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
 
getStorageHandler(Configuration, String) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
getStorageHandler() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getStorageHandler() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getStorageHandler() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getStorageHandler() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getStoredStats() - Method in class org.apache.hadoop.hive.ql.exec.Stat
 
getStream() - Method in class org.apache.hadoop.hive.ql.Context
 
getStreamAliases() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getStrExprProcessor() - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get StrExprProcessor.
getString() - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BinaryWritable.DicBinaryWritable
 
getString() - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BinaryWritable
 
getStringValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
getStringValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
getStringValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
getStripes() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the list of stripes.
getStripeStatistics() - Method in class org.apache.hadoop.hive.ql.io.orc.Metadata
Return list of stripe level column statistics
getStructFieldData(Object, StructField) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
getStructFieldRef(String) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
getStructFieldsDataAsList(Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
getSubqAliases() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getSubqForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getSubQuery() - Method in class org.apache.hadoop.hive.ql.parse.QBSubQuery
 
getSubQuery() - Method in interface org.apache.hadoop.hive.ql.parse.SubQueryUtils.ISubQueryJoinInfo
 
getSubQueryAST() - Method in class org.apache.hadoop.hive.ql.parse.QBSubQuery
 
getSubQueryAST() - Method in interface org.apache.hadoop.hive.ql.parse.SubQueryUtils.ISubQueryJoinInfo
 
getSubQueryExprProcessor() - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get SubQueryExprProcessor.
getSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.BinaryColumnStatistics
 
getSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.DecimalColumnStatistics
Get the sum of the values of the column.
getSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.DoubleColumnStatistics
Get the sum of the values in the column.
getSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.IntegerColumnStatistics
Get the sum of the column.
getSum() - Method in interface org.apache.hadoop.hive.ql.io.orc.StringColumnStatistics
Get the total length of all strings
getSumIgnoreNegatives(List<Long>) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get sum of all values in the list that are >0
getSupportedStatistics() - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Returns the set of supported statistics
getSwitchDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getT() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
getTabAlias() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
getTabAlias() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.BaseColumnInfo
 
getTabAlias() - Method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBExprProcCtx
 
getTabAlias() - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcCtx
 
getTabAlias() - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcCtx
 
getTabAlias() - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprPrunerInfo
 
getTabAlias() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
getTabAliases() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getTable() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
Get the table associated with the entity.
getTable() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DataContainer
 
getTable() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.TableAliasInfo
 
getTable(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns metadata for the table named tableName
getTable(String, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns metadata for the table named tableName
getTable(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns metadata of the table
getTable(String, String, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns metadata of the table
getTable() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getTable(TableScanOperator) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.ShowColumnsDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.ShowCreateTableDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.ShowTblPropertiesDesc
 
getTableAccessInfo() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Gets the table access information.
getTableAccessInfo() - Method in class org.apache.hadoop.hive.ql.parse.TableAccessCtx
 
getTableAccessInfo() - Method in class org.apache.hadoop.hive.ql.QueryPlan
Gets the table access information.
getTableAlias() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
getTableColumnStatistics(String, String, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getTableColumnStats(Table, List<ColumnInfo>, List<String>) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get table level column statistics from metastore for needed columns
getTableDef() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
getTableDesc() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
getTableDesc(Table) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getTableDesc(String, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getTableDesc() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getTableDesc() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getTableDesc(Class<? extends Deserializer>, String, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor of given serde with the separatorCode and column names (comma separated string).
getTableDesc(Class<? extends Deserializer>, String, String, boolean) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor of the serde specified with the separatorCode and column names (comma separated string), and whether the last column should take the rest of the line.
getTableDesc(Class<? extends Deserializer>, String, String, String, boolean) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
getTableDesc(Class<? extends Deserializer>, String, String, String, boolean, boolean) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
getTableDesc(Class<? extends Deserializer>, String, String, String, boolean, boolean, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
getTableDesc(CreateTableDesc, String, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate a table descriptor from a createTableDesc.
getTableForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getTableFunctionResolver(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getTableInfo() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getTableInformation(Table) - Static method in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatUtils
 
getTableName() - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult.PartitionResult
 
getTableName() - Method in exception org.apache.hadoop.hive.ql.metadata.InvalidTableException
 
getTableName() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getTableName() - Method in class org.apache.hadoop.hive.ql.parse.AlterTablePartMergeFilesDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableAlterPartDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.DropIndexDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.RenamePartitionDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.ShowColumnsDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.ShowCreateTableDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.ShowIndexesDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.ShowTblPropertiesDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.TruncateTableDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.UnlockTableDesc
 
getTableNames() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getTableProperties() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
getTablesByPattern(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns all existing tables from default database which match the given pattern.
getTablesByPattern(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns all existing tables from the specified database which match the given pattern.
getTableScanMapJoin() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory
 
getTableScanProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
Factory method to get the ColumnPrunerDefaultProc class.
getTableScanRule() - Static method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory
 
getTableScanRule() - Static method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory
 
getTableScanTraitSet(RelOptCluster, RelTraitSet, RelOptHiveTable, RelDataType) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.TraitsUtil
 
getTablesForDb(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns all existing tables from the given database which match the given pattern.
getTablesNotInMs() - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult
 
getTablesNotOnFs() - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult
 
getTableSpec(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getTableSpec() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
This method is used only for the anlayze command to get the partition specs
getTableSpecs() - Method in class org.apache.hadoop.hive.ql.plan.StatsNoJobWork
 
getTableSpecs() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
getTableToColumnAccessMap() - Method in class org.apache.hadoop.hive.ql.parse.ColumnAccessInfo
 
getTableType() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getTableViewURI() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
 
getTabName() - Method in class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
getTabNameForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getTabPropsForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getTabSample(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getTag() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getTagLength() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getTagOrder() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getTagOrder() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
The order in which tables should be processed when joining.
getTagToAlias() - Method in class org.apache.hadoop.hive.ql.plan.SMBJoinDesc
 
getTagToInput() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getTagToValueDesc() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getTargetDir() - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
getTargetDirs() - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
getTargetSize(long) - Method in class org.apache.hadoop.hive.ql.parse.SplitSample
 
getTargetSplit() - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat.SymlinkTextInputSplit
Gets the target split, i.e.
getTask() - Method in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
getTaskError() - Method in class org.apache.hadoop.hive.ql.exec.TaskResult
 
getTaskHandle() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getTaskId(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Gets the task id if we are running as a Hadoop job.
getTaskIdFromFilename(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Get the task id from the filename.
getTaskInfoMap() - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryViewer
 
getTaskOutPath(String) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
Update OutPath according to tmpPath.
getTaskResult() - Method in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
getTaskRunnerID() - Static method in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
getTasks(HiveConf, Object) - Method in interface org.apache.hadoop.hive.ql.plan.ConditionalResolver
All conditional resolvers implement this interface.
getTasks(HiveConf, Object) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin
 
getTasks(HiveConf, Object) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles
 
getTasks(HiveConf, Object) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverSkewJoin
 
getTaskTag() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getTaskTmpDir() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
getTaskToAliases() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
getTbl() - Method in class org.apache.hadoop.hive.ql.plan.HashTableDummyDesc
 
getTblAliasToBucketedFilePathsInEachPartition() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
getTblAliasToNumberOfBucketsInEachPartition() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
getTblColPosition() - Method in class org.apache.hadoop.hive.ql.plan.SkewedColumnPositionPair
 
getTblDesc() - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
Return the tableDesc of the fetchWork.
getTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getTblDir() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
getTblProps() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getTblProps() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getTblProps() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
getTblProps() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getTempFilesFromConf(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
getText(ASTNode) - Static method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
getText() - Method in class org.apache.hadoop.hive.ql.parse.ASTErrorNode
 
getTezCounters() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezTask
 
getTezDir(Path) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
Gets the tez dir that belongs to the hive scratch dir
getTezScratchDir() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
getTezSession() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getTezTasks(List<Task<? extends Serializable>>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getTFunction() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
getThriftHiveObjectRef(HivePrivilegeObject) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
Convert thrift HiveObjectRef to plugin HivePrivilegeObject
getThriftHiveObjType(HivePrivilegeObject.HivePrivilegeObjectType) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
Convert plugin privilege object type to thrift type
getThriftPrincipalType(HivePrincipal.HivePrincipalType) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
Convert authorization plugin principal type to thrift principal type
getThriftPrivilegeGrantInfo(HivePrivilege, HivePrincipal, boolean, int) - Static method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils
Get thrift privilege grant info
getThriftSchema() - Method in class org.apache.hadoop.hive.ql.Driver
Get a Schema with fields represented with Thrift DDL types
getTimeNanoSec(Timestamp) - Static method in class org.apache.hadoop.hive.ql.exec.vector.TimestampUtils
 
getTimestampColumnName() - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
 
getTmpHDFSPath() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getTmpOutputFile() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getTmpPath() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getToken() - Method in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeType
 
getTokenRewriteStream() - Method in class org.apache.hadoop.hive.ql.Context
 
getToPath() - Method in class org.apache.hadoop.hive.ql.plan.CopyWork
 
getTopN() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getTopNExplain() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getTopNMemoryUsage() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getTopNMemoryUsageExplain() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getTopOperators() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
getTopOperators() - Method in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
getTopOperators() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getTopOps() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getTopSelOps() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getTopToProps() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getTopToTable() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getToRR() - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
getTotalFiles() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getTotalInputFileSize(ContentSummary, MapWork, double) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Computes the total input file size.
getTotalInputNumFiles(ContentSummary, MapWork, double) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Computes the total number of input files.
getTotalKnownInputSize(Context, MapWork, Map<String, ArrayList<String>>, HashMap<String, Long>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.AbstractJoinTaskDispatcher
 
getTotalLength() - Method in class org.apache.hadoop.hive.ql.metadata.InputEstimator.Estimation
 
getTotalLength() - Method in class org.apache.hadoop.hive.ql.parse.SplitSample
 
getTotalSize(Table) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get total size of a give table
getToWalk() - Method in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
 
getToWalk() - Method in class org.apache.hadoop.hive.ql.lib.TaskGraphWalker
 
getTPartition() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
Should be only used by serialization.
getTransactionId() - Method in class org.apache.hadoop.hive.ql.io.RecordIdentifier
What was the original transaction id for the last row?
getTransformProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getTrueCount() - Method in interface org.apache.hadoop.hive.ql.io.orc.BooleanColumnStatistics
 
getTruncatedPathToAliases() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
This is used to display and verify output of "Path -> Alias" in test framework.
getTruncateTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getTryCount() - Method in class org.apache.hadoop.hive.ql.Context
 
getTryCount() - Method in class org.apache.hadoop.hive.ql.Driver
 
getTSProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getTSProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getTTable() - Method in class org.apache.hadoop.hive.ql.metadata.Table
This function should only be used in serialization.
getTTDesc() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
getTxnManager(HiveConf) - Method in class org.apache.hadoop.hive.ql.lockmgr.TxnManagerFactory
Create a new transaction manager.
getTxnManagerFactory() - Static method in class org.apache.hadoop.hive.ql.lockmgr.TxnManagerFactory
Get the singleton instance of this factory.
getTyp() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.CollectOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ColumnStatsTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.CopyTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.DDLTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.DependencyCollectionTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.DummyStoreOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ExtractOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.FilterOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ForwardOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.FunctionTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.HashTableDummyOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.JoinOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.LateralViewForwardOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.LateralViewJoinOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ListSinkOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.MoveTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.MuxOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.Operator
Return the type of the specific operator among the types in OperatorType.
getType() - Method in class org.apache.hadoop.hive.ql.exec.PTFOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.StatsNoJobTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.StatsTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.Task
Should be overridden to return the type of the specific task among the types in StageType.
getType() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.UnionOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IdentityExpression
 
getType(String) - Static method in enum org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.ArgumentType
 
getType() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
Get the type of the entity.
getType() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
getType() - Method in class org.apache.hadoop.hive.ql.index.IndexMetadataChangeTask
 
getType() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.BlockMergeTask
 
getType() - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanTask
 
getType() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateTask
 
getType() - Method in interface org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf
Get the type of the column and literal.
getType(RelOptCluster, RowResolver, List<String>) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.translator.TypeConverter
 
getType() - Method in class org.apache.hadoop.hive.ql.parse.ASTErrorNode
 
getType() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFQueryInputSpec
 
getType() - Method in class org.apache.hadoop.hive.ql.parse.QBSubQuery.SubQueryTypeDef
 
getType() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
getType() - Method in class org.apache.hadoop.hive.ql.plan.ArchiveWork
 
getType() - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
getType() - Method in class org.apache.hadoop.hive.ql.plan.PrincipalDesc
 
getType() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFQueryInputDef
 
getType() - Method in class org.apache.hadoop.hive.ql.plan.TezWork.Dependency
 
getType() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrincipal
 
getType() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
 
getTypeArray() - Method in class org.apache.hadoop.hive.ql.parse.InputSignature
 
getTypeCheckCtx() - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
getTypeInfo() - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
getTypeInfo() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnListDesc
 
getTypeInfo() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
getTypeInfo() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToChar
 
getTypeInfo() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToDecimal
 
getTypeInfo() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToVarchar
 
getTypeInfo() - Method in interface org.apache.hadoop.hive.ql.udf.SettableUDF
 
getTypeInfoForPrimitiveCategory(PrimitiveTypeInfo, PrimitiveTypeInfo, PrimitiveObjectInspector.PrimitiveCategory) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Given 2 TypeInfo types and the PrimitiveCategory selected as the common class between the two, return a TypeInfo corresponding to the common PrimitiveCategory, and with type qualifiers (if applicable) that match the 2 TypeInfo types.
getTypeName() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
getTypeName() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveArrayInspector
 
getTypeName(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.DDLSemanticAnalyzer
 
getTypes() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Get the list of types contained in the file.
getTypeString() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
getTypeString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnListDesc
 
getTypeString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
getUCtx() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getUDAFClass() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge
 
getUdafEvaluator() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
getUdfClass() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
getUdfClassName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
getUDFClassType(Class<?>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionUtils
Determine the UDF class type of the class
getUdfName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
 
getUdfName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
getUDTFName() - Method in class org.apache.hadoop.hive.ql.plan.UDTFDesc
 
getUDTFProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getUgi() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getUnescapedName(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Get dequoted name from a table/column node.
getUnescapedName(ASTNode, String) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getUnescapedUnqualifiedTableName(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Get the unqualified name from a table node.
getUnionNoProcessFile() - Static method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory
 
getUnionOperators() - Method in class org.apache.hadoop.hive.ql.plan.UnionWork
 
getUnionParseContext(UnionOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext
 
getUnionProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getUnionTask(UnionOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getUnixScriptNameFor(String) - Static method in class org.apache.hadoop.hive.ql.util.DosToUnix
 
getUnknownUnion() - Static method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory
 
getUnlockDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getUnlockTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getUnparsedColumnNamesFromFieldSchema(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
Convert FieldSchemas to columnNames with backticks around them.
getUnparseTranslator() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getUpdate(String) - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Prepares UPDATE statement issued when updating existing statistics
getURL(JobConf) - Static method in class org.apache.hadoop.hive.ql.exec.mr.JobTrackerURLResolver
 
getUsageAlias() - Method in class org.apache.hadoop.hive.ql.parse.ASTNodeOrigin
 
getUsageNode() - Method in class org.apache.hadoop.hive.ql.parse.ASTNodeOrigin
 
getUsedBins() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Returns the number of bins currently being used by the histogram.
getUser() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
getUserFromAuthenticator() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
getUserGrants() - Method in class org.apache.hadoop.hive.ql.session.CreateTableAutomaticGrant
 
getUserName() - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContext
 
getUserName() - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
getUserName() - Method in class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
getUserName() - Method in interface org.apache.hadoop.hive.ql.security.HiveAuthenticationProvider
 
getUserName() - Method in class org.apache.hadoop.hive.ql.security.SessionStateConfigUserAuthenticator
 
getUserName() - Method in class org.apache.hadoop.hive.ql.security.SessionStateUserAuthenticator
 
getUserName() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getUTask() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
getUtils() - Static method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
getValidTxns() - Method in class org.apache.hadoop.hive.ql.lockmgr.DbTxnManager
 
getValidTxns() - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveTxnManager
Get the transactions that are currently valid.
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColAndScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColOrScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarAndColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarOrColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarDivideLongColumn
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColScalar
 
getValue() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatScalarCol
 
getValue(String) - Static method in enum org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression.Type
 
getValue() - Method in enum org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.ArgumentType
 
getValue() - Method in enum org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.InputExpressionType
 
getValue() - Method in enum org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Mode
 
getValue() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
getValue() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeNullDesc
 
getValueBuffer() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileValueBufferWrapper
 
getValueClass() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeRecordReader
 
getValueClass() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
getValueClass() - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
getValueCols() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getValueColsString() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getValueContext() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainerSerDe
 
getValueEval() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator
 
getValueFilteredTblDescs() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getValues() - Method in class org.apache.hadoop.hive.ql.metadata.DummyPartition
 
getValues() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getValueSerializeInfo() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getValuesSerializeInfos() - Method in class org.apache.hadoop.hive.ql.plan.DemuxDesc
 
getValueTblDescs() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getValueTblDescs() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getValueTblFilteredDescs() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getVarcharTypeInfo(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.ParseUtils
 
getVariableSize() - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorAggregateExpression.AggregationBuffer
 
getVariableSize(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferBatch
 
getVariableSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
getVariableSize(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapperBatch
 
getVCSObjectInspector(List<VirtualColumn>) - Static method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
getVectorExpression(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
getVectorExpression(ExprNodeDesc, VectorExpressionDescriptor.Mode) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
Returns a vector expression for a given expression description.
getVectorExpressionClass(Class<?>, VectorExpressionDescriptor.Descriptor) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor
 
getVectorExpressions(List<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
getVectorExpressions(List<ExprNodeDesc>, VectorExpressionDescriptor.Mode) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
getVectorHashKeyWrappers() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapperBatch
Accessor for the batch-sized array of key wrappers.
getVectorizedBatchResult(int) - Method in class org.apache.hadoop.hive.ql.exec.TopNHash
Get vectorized batch result for particular index.
getVectorizedKeyDistLength(int) - Method in class org.apache.hadoop.hive.ql.exec.TopNHash
After vectorized batch is processed, can return distribution keys length of a key.
getVectorizedKeyToForward(int) - Method in class org.apache.hadoop.hive.ql.exec.TopNHash
After vectorized batch is processed, can return the key that caused a particular row to be forwarded.
getVectorMode() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getVectorModeOn() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getVectorModeOn() - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
getVectorOperator(T, VectorizationContext) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
 
getVersion() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferRow
Versioning used to detect staleness of the index cached for benefit of VectorAggregationBufferBatch.
getVersion() - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
 
getVersion() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
getvExpressions() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator
 
getVExpressions() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator
 
getViewAliasToInput() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getViewExpandedText() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getViewExpandedText() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getViewName() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getViewOriginalText() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getViewOriginalText() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getVirtualCols(List<RexNode>) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.HiveOptiqUtil
Get list of virtual columns from the given list of projections.
getVirtualCols() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveProjectRel
 
getVirtualCols() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getVirtualColumns() - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcCtx
 
getWdwProcessingOutputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.WindowingTableFunctionResolver
 
getWFnEval() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
getWhrForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getWindowExpressions() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec
 
getWindowFrame() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowSpec
 
getWindowFrame() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
getWindowFunctionInfo(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getWindowFunctions() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowTableFunctionDef
 
getWindowingExprsForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getWindowingSpec(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getWindowingTableFunction() - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getWindowSpec() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFunctionSpec
 
getWindowSpecs() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec
 
getWork() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
getWork() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getWorkMap() - Method in class org.apache.hadoop.hive.ql.plan.TezWork
getWorkMap returns a map of "vertex name" to BaseWork
getWorks() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
getWritableKeyValue(VectorHashKeyWrapper, int, VectorExpressionWriter) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapperBatch
Get the row-mode writable object value of a key from a key wrapper
getWritableObject(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
 
getWritableObject(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.ColumnVector
 
getWritableObject(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.DecimalColumnVector
 
getWritableObject(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.DoubleColumnVector
 
getWritableObject(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.LongColumnVector
 
getWritableObjectInspector() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnListDesc
 
getWritableObjectInspector() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
getWritableObjectInspector() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
getWritableObjectInspector() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
getWritableSize(ObjectInspector, Object) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Get size of primitive data types based on their respective writable object inspector
getWriter() - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterContext
 
getWriteType() - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
Determine which type of write this is.
GlobalLimitCtx - Class in org.apache.hadoop.hive.ql.parse
context for pruning inputs.
GlobalLimitCtx() - Constructor for class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
GlobalLimitOptimizer - Class in org.apache.hadoop.hive.ql.optimizer
This optimizer is used to reduce the input size for the query for queries which are specifying a limit.
GlobalLimitOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GlobalLimitOptimizer
 
go() - Method in class org.apache.hadoop.hive.ql.exec.AutoProgressor
 
GrantDesc - Class in org.apache.hadoop.hive.ql.plan
 
GrantDesc(PrivilegeObjectDesc, List<PrivilegeDesc>, List<PrincipalDesc>, String, PrincipalType, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.GrantDesc
 
GrantPrivAuthUtils - Class in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
Utility class to authorize grant/revoke privileges
GrantPrivAuthUtils() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.GrantPrivAuthUtils
 
grantPrivileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
grantPrivileges(List<HivePrincipal>, List<HivePrivilege>, HivePrivilegeObject, HivePrincipal, boolean) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessController
 
grantPrivileges(List<HivePrincipal>, List<HivePrivilege>, HivePrivilegeObject, HivePrincipal, boolean) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
Grant privileges for principals on the object
grantPrivileges(List<HivePrincipal>, List<HivePrivilege>, HivePrivilegeObject, HivePrincipal, boolean) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
grantPrivileges(List<HivePrincipal>, List<HivePrivilege>, HivePrivilegeObject, HivePrincipal, boolean) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
GrantRevokeRoleDDL - Class in org.apache.hadoop.hive.ql.plan
 
GrantRevokeRoleDDL() - Constructor for class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
GrantRevokeRoleDDL(boolean, List<String>, List<PrincipalDesc>, String, PrincipalType, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
grantRole(String, String, PrincipalType, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
grantRole(List<HivePrincipal>, List<String>, boolean, HivePrincipal) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessController
 
grantRole(List<HivePrincipal>, List<String>, boolean, HivePrincipal) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
Grant roles in given roles list to principals in given hivePrincipals list
grantRole(List<HivePrincipal>, List<String>, boolean, HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
grantRole(List<HivePrincipal>, List<String>, boolean, HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
GraphWalker - Interface in org.apache.hadoop.hive.ql.lib
Interface for operator graph walker.
GROOVY - Static variable in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
GroupByDesc - Class in org.apache.hadoop.hive.ql.plan
GroupByDesc.
GroupByDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
GroupByDesc(GroupByDesc.Mode, ArrayList<String>, ArrayList<ExprNodeDesc>, ArrayList<AggregationDesc>, boolean, float, float, List<Integer>, boolean, int, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
GroupByDesc(GroupByDesc.Mode, ArrayList<String>, ArrayList<ExprNodeDesc>, ArrayList<AggregationDesc>, boolean, boolean, float, float, List<Integer>, boolean, int, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
GroupByDesc.Mode - Enum in org.apache.hadoop.hive.ql.plan
Mode.
GroupByOperator - Class in org.apache.hadoop.hive.ql.exec
GroupBy operator implementation.
GroupByOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
GroupByOptimizer - Class in org.apache.hadoop.hive.ql.optimizer
This transformation does group by optimization.
GroupByOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer
 
GroupByOptimizer.GroupByOptimizerContext - Class in org.apache.hadoop.hive.ql.optimizer
 
GroupByOptimizer.GroupByOptimizerContext(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.GroupByOptimizerContext
 
GroupByOptimizer.GroupByOptimizerSortMatch - Enum in org.apache.hadoop.hive.ql.optimizer
 
GroupByOptimizer.SortGroupByProcessor - Class in org.apache.hadoop.hive.ql.optimizer
SortGroupByProcessor.
GroupByOptimizer.SortGroupByProcessor(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.SortGroupByProcessor
 
GroupByOptimizer.SortGroupBySkewProcessor - Class in org.apache.hadoop.hive.ql.optimizer
SortGroupByProcessor.
GroupByOptimizer.SortGroupBySkewProcessor(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.SortGroupBySkewProcessor
 
GROUPINGID - Static variable in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
GROUPINGID is used with GROUP BY GROUPINGS SETS, ROLLUP and CUBE.
groupingSet2BitSet(int) - Static method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 

H

HADOOP_LOCAL_FS - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
The object in the reducer are composed of these top level fields.
HadoopDefaultAuthenticator - Class in org.apache.hadoop.hive.ql.security
 
HadoopDefaultAuthenticator() - Constructor for class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
HadoopDefaultMetastoreAuthenticator - Class in org.apache.hadoop.hive.ql.security
 
HadoopDefaultMetastoreAuthenticator() - Constructor for class org.apache.hadoop.hive.ql.security.HadoopDefaultMetastoreAuthenticator
 
HadoopJobExecHelper - Class in org.apache.hadoop.hive.ql.exec.mr
 
HadoopJobExecHelper(JobConf, SessionState.LogHelper, Task<? extends Serializable>, HadoopJobExecHook) - Constructor for class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
HadoopJobExecHook - Interface in org.apache.hadoop.hive.ql.exec.mr
 
handle(HiveHistory.RecordTypes, Map<String, String>) - Method in interface org.apache.hadoop.hive.ql.history.HiveHistory.Listener
 
handle(HiveHistory.RecordTypes, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryViewer
Implementation Listener interface function.
handleEvents(List<Event>) - Method in class org.apache.hadoop.hive.ql.exec.tez.HivePreWarmProcessor
 
handleEvents(List<Event>) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezProcessor
 
handleSkew(int) - Method in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
hasAddedResource() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
hasAnyNulls(int, boolean[]) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKey
 
hasAnyNulls(int, boolean[]) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyBytes
 
hasAnyNulls(int, boolean[]) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyObject
 
hasBase() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcNewSplit
 
hasBase() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSplit
 
hasClusterBy() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasColumnExpr(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
Whether the expression contains a column node or not.
hasDistributeBy() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasDynamicPartitions() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
hasDynamicPartitions() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
hasExprToColumnAlias(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
hasFile - Variable in class org.apache.hadoop.hive.ql.optimizer.SamplePruner.AddPathReturnStatus
 
hasFilterTag() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectSerDeContext
 
hasFooter() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcNewSplit
 
hasFooter() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSplit
 
hasGroupBy(Operator<? extends OperatorDesc>, MapJoinResolver.LocalMapJoinProcCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory.LocalMapJoinProcessor
 
hasGroupBy() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.errors.ErrorAndSolution
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyBytes
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyObject
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
hashCode() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
Hashcode function.
hashCode() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DependencyKey
 
hashCode() - Method in class org.apache.hadoop.hive.ql.io.HiveKey
 
hashCode() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcStruct
 
hashCode() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
hashCode() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
hashCode() - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveArrayInspector
 
hashCode() - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
hashCode() - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BinaryWritable
 
hashCode() - Method in class org.apache.hadoop.hive.ql.metadata.Dimension
 
hashCode(Object) - Method in class org.apache.hadoop.hive.ql.metadata.Dimension
 
hashCode(Object) - Method in class org.apache.hadoop.hive.ql.metadata.RandomDimension
 
hashCode() - Method in class org.apache.hadoop.hive.ql.metadata.Sample
 
hashCode() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
hashCode() - Method in class org.apache.hadoop.hive.ql.parse.InputSignature
 
hashCode() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderExpression
 
hashCode() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderSpec
 
hashCode() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionExpression
 
hashCode() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitioningSpec
 
hashCode() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionSpec
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc.ExprNodeDescEqualityWrapper
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
hashCode() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrincipal
 
hashCode() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilege
 
hashMap(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
hashMapEntry() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
HashMapWrapper - Class in org.apache.hadoop.hive.ql.exec.persistence
Simple wrapper for persistent Hashmap implementing only the put/get/remove/clear interface.
HashMapWrapper(int, float) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
Constructor.
HashMapWrapper(Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
HashMapWrapper(int) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
HashMapWrapper() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
hashSet(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
HashTableDummyDesc - Class in org.apache.hadoop.hive.ql.plan
HashTable Dummy Descriptor implementation.
HashTableDummyDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.HashTableDummyDesc
 
HashTableDummyOperator - Class in org.apache.hadoop.hive.ql.exec
 
HashTableDummyOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.HashTableDummyOperator
 
HashTableLoader - Interface in org.apache.hadoop.hive.ql.exec
HashTableLoader is an interface used by MapJoinOperator used to load the hashtables needed to process the join.
HashTableLoader - Class in org.apache.hadoop.hive.ql.exec.mr
HashTableLoader for MR loads the hashtable for MapJoins from local disk (hashtables are distributed by using the DistributedCache.
HashTableLoader() - Constructor for class org.apache.hadoop.hive.ql.exec.mr.HashTableLoader
 
HashTableLoader - Class in org.apache.hadoop.hive.ql.exec.tez
HashTableLoader for Tez constructs the hashtable from records read from a broadcast edge.
HashTableLoader() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.HashTableLoader
 
HashTableLoaderFactory - Class in org.apache.hadoop.hive.ql
HashTableLoaderFactory is used to determine the strategy of loading the hashtables for the MapJoinOperator
HashTableSinkDesc - Class in org.apache.hadoop.hive.ql.plan
Map Join operator Descriptor implementation.
HashTableSinkDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
HashTableSinkDesc(MapJoinDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
HashTableSinkOperator - Class in org.apache.hadoop.hive.ql.exec
 
HashTableSinkOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
HashTableSinkOperator(MapJoinOperator) - Constructor for class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
hasJobFlowCorrelation() - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.IntraQueryCorrelation
 
hasJoin() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasJoinFollowedByGroupBy() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasMetadataValue(String) - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Did the user set the given metadata value.
hasNext() - Method in class org.apache.hadoop.hive.ql.exec.PTFUtils.ReverseIterator
 
hasNext() - Method in interface org.apache.hadoop.hive.ql.io.orc.RecordReader
Does the reader have more rows available.
hasNext() - Method in class org.apache.hadoop.hive.ql.parse.WindowingComponentizer
 
hasOrderBy() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasPTF() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasRecordsInBuffer() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
 
hasReduce() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
hasReduce() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
hasReduce() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
hasReduceTasks(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.Driver
 
hasResources(String[]) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
hasSortBy() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasStagedAlias() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
hasTableAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
hasTableSample(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
hasUnknownPartitions() - Method in class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
 
hasVariableSize() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorAggregateExpression
 
hasVirtualCols() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
hasWindowing() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
hasWindowingSpec(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
heartbeat() - Method in class org.apache.hadoop.hive.ql.exec.Heartbeater
Send a heartbeat to the metastore for locks and transactions.
heartbeat() - Method in class org.apache.hadoop.hive.ql.lockmgr.DbTxnManager
 
heartbeat() - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveTxnManager
Send a heartbeat to the transaction management storage so other Hive clients know that the transaction and locks held by this client are still valid.
Heartbeater - Class in org.apache.hadoop.hive.ql.exec
Class to handle heartbeats for MR and Tez tasks.
Heartbeater(HiveTxnManager, Configuration) - Constructor for class org.apache.hadoop.hive.ql.exec.Heartbeater
 
hiddenFileFilter - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
HINTED_MAPJOIN - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
HINTED_MAPJOIN_LOCAL - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
Hive - Class in org.apache.hadoop.hive.ql.metadata
This class has functions that implement meta data/DDL operations using calls to the metastore.
HIVE_COLUMN_ORDER_ASC - Static variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
HIVE_COLUMN_ORDER_DESC - Static variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
HIVE_LIST_BUCKETING_DEFAULT_DIR_NAME - Static variable in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPrunerUtils
 
HIVE_LIST_BUCKETING_DEFAULT_KEY - Static variable in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPrunerUtils
 
HIVE_PASSTHROUGH_OF_CLASSNAME - Static variable in class org.apache.hadoop.hive.ql.io.HivePassThroughOutputFormat
 
HIVE_PASSTHROUGH_STORAGEHANDLER_OF_JOBCONFKEY - Static variable in class org.apache.hadoop.hive.ql.io.HivePassThroughOutputFormat
 
HIVE_SCHEMA_KEY - Static variable in class org.apache.hadoop.hive.ql.io.parquet.read.DataWritableReadSupport
 
HiveAccessControlException - Exception in org.apache.hadoop.hive.ql.security.authorization.plugin
Exception thrown by the Authorization plugin api (v2).
HiveAccessControlException() - Constructor for exception org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessControlException
 
HiveAccessControlException(String) - Constructor for exception org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessControlException
 
HiveAccessControlException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessControlException
 
HiveAccessControlException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessControlException
 
HiveAccessController - Interface in org.apache.hadoop.hive.ql.security.authorization.plugin
Interface that is invoked by access control commands, including grant/revoke role/privileges, create/drop roles, and commands to read the state of authorization rules.
HiveAggregateRel - Class in org.apache.hadoop.hive.ql.optimizer.optiq.reloperators
 
HiveAggregateRel(RelOptCluster, RelTraitSet, RelNode, BitSet, List<AggregateCall>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveAggregateRel
 
HiveAuthenticationProvider - Interface in org.apache.hadoop.hive.ql.security
HiveAuthenticationProvider is an interface for authentication.
HiveAuthorizationProvider - Interface in org.apache.hadoop.hive.ql.security.authorization
Hive's pluggable authorization provider interface
HiveAuthorizationProviderBase - Class in org.apache.hadoop.hive.ql.security.authorization
 
HiveAuthorizationProviderBase() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
HiveAuthorizationTaskFactory - Interface in org.apache.hadoop.hive.ql.parse.authorization
HiveAuthorizationTaskFactory creates DDL authorization related tasks.
HiveAuthorizationTaskFactoryImpl - Class in org.apache.hadoop.hive.ql.parse.authorization
Default implementation of HiveAuthorizationTaskFactory
HiveAuthorizationTaskFactoryImpl(HiveConf, Hive) - Constructor for class org.apache.hadoop.hive.ql.parse.authorization.HiveAuthorizationTaskFactoryImpl
 
HiveAuthorizationValidator - Interface in org.apache.hadoop.hive.ql.security.authorization.plugin
Interface used to check if user has privileges to perform certain action.
HiveAuthorizer - Interface in org.apache.hadoop.hive.ql.security.authorization.plugin
Interface for hive authorization plugins.
HiveAuthorizer.VERSION - Enum in org.apache.hadoop.hive.ql.security.authorization.plugin
 
HiveAuthorizerFactory - Interface in org.apache.hadoop.hive.ql.security.authorization.plugin
Implementation of this interface specified through hive configuration will be used to create HiveAuthorizer instance used for hive authorization.
HiveAuthorizerImpl - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
Convenience implementation of HiveAuthorizer.
HiveAuthorizerImpl(HiveAccessController, HiveAuthorizationValidator) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
HiveAuthzPluginException - Exception in org.apache.hadoop.hive.ql.security.authorization.plugin
Exception thrown by the Authorization plugin api (v2).
HiveAuthzPluginException() - Constructor for exception org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzPluginException
 
HiveAuthzPluginException(String) - Constructor for exception org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzPluginException
 
HiveAuthzPluginException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzPluginException
 
HiveAuthzPluginException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzPluginException
 
HiveBinaryOutputFormat<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
HiveBinaryOutputFormat writes out the values consecutively without any separators.
HiveBinaryOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.HiveBinaryOutputFormat
 
HiveCommand - Enum in org.apache.hadoop.hive.ql.processors
 
HiveCompactIndexInputFormat - Class in org.apache.hadoop.hive.ql.index.compact
 
HiveCompactIndexInputFormat() - Constructor for class org.apache.hadoop.hive.ql.index.compact.HiveCompactIndexInputFormat
 
HIVECONF_PREFIX - Static variable in class org.apache.hadoop.hive.ql.processors.SetProcessor
 
HiveContextAwareRecordReader<K,V> - Class in org.apache.hadoop.hive.ql.io
This class prepares an IOContext, and provides the ability to perform a binary search on the data.
HiveContextAwareRecordReader(JobConf) - Constructor for class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
HiveContextAwareRecordReader(RecordReader) - Constructor for class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
HiveContextAwareRecordReader(RecordReader, JobConf) - Constructor for class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
HiveCost - Class in org.apache.hadoop.hive.ql.optimizer.optiq.cost
 
HiveCostUtil - Class in org.apache.hadoop.hive.ql.optimizer.optiq.cost
 
HiveCostUtil() - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCostUtil
 
HIVECOUNTERCREATEDFILES - Static variable in class org.apache.hadoop.hive.ql.exec.Operator
 
HIVECOUNTERFATAL - Static variable in class org.apache.hadoop.hive.ql.exec.Operator
 
HiveDefaultRelMetadataProvider - Class in org.apache.hadoop.hive.ql.optimizer.optiq
Distinct row count and Selectivity is overridden for Hive.
HiveDriverRunHook - Interface in org.apache.hadoop.hive.ql
HiveDriverRunHook allows Hive to be extended with custom logic for processing commands.
HiveDriverRunHookContext - Interface in org.apache.hadoop.hive.ql
Context information provided by Hive to implementations of HiveDriverRunHook.
HiveDriverRunHookContextImpl - Class in org.apache.hadoop.hive.ql
 
HiveDriverRunHookContextImpl(Configuration, String) - Constructor for class org.apache.hadoop.hive.ql.HiveDriverRunHookContextImpl
 
HiveException - Exception in org.apache.hadoop.hive.ql.metadata
Generic exception class for Hive.
HiveException() - Constructor for exception org.apache.hadoop.hive.ql.metadata.HiveException
 
HiveException(String) - Constructor for exception org.apache.hadoop.hive.ql.metadata.HiveException
 
HiveException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.metadata.HiveException
 
HiveException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.ql.metadata.HiveException
 
HiveException(ErrorMsg, String...) - Constructor for exception org.apache.hadoop.hive.ql.metadata.HiveException
 
HiveException(Throwable, ErrorMsg, String...) - Constructor for exception org.apache.hadoop.hive.ql.metadata.HiveException
This is the recommended constructor to use since it helps use canonical messages throughout.
HiveFatalException - Exception in org.apache.hadoop.hive.ql.metadata
 
HiveFatalException() - Constructor for exception org.apache.hadoop.hive.ql.metadata.HiveFatalException
 
HiveFatalException(String) - Constructor for exception org.apache.hadoop.hive.ql.metadata.HiveFatalException
 
HiveFatalException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.metadata.HiveFatalException
 
HiveFatalException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.ql.metadata.HiveFatalException
 
HiveFileFormatUtils - Class in org.apache.hadoop.hive.ql.io
An util class for various Hive file format tasks.
HiveFilterRel - Class in org.apache.hadoop.hive.ql.optimizer.optiq.reloperators
 
HiveFilterRel(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveFilterRel
 
HiveGroupConverter - Class in org.apache.hadoop.hive.ql.io.parquet.convert
 
HiveGroupConverter() - Constructor for class org.apache.hadoop.hive.ql.io.parquet.convert.HiveGroupConverter
 
HiveHistory - Interface in org.apache.hadoop.hive.ql.history
HiveHistory.
HiveHistory.Info - Class in org.apache.hadoop.hive.ql.history
Info.
HiveHistory.Info() - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistory.Info
 
HiveHistory.Keys - Enum in org.apache.hadoop.hive.ql.history
Keys.
HiveHistory.Listener - Interface in org.apache.hadoop.hive.ql.history
Listener interface.
HiveHistory.QueryInfo - Class in org.apache.hadoop.hive.ql.history
QueryInfo.
HiveHistory.QueryInfo() - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistory.QueryInfo
 
HiveHistory.RecordTypes - Enum in org.apache.hadoop.hive.ql.history
RecordTypes.
HiveHistory.SessionInfo - Class in org.apache.hadoop.hive.ql.history
SessionInfo.
HiveHistory.SessionInfo() - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistory.SessionInfo
 
HiveHistory.TaskInfo - Class in org.apache.hadoop.hive.ql.history
TaskInfo.
HiveHistory.TaskInfo() - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistory.TaskInfo
 
HiveHistoryImpl - Class in org.apache.hadoop.hive.ql.history
HiveHistory.
HiveHistoryImpl(SessionState) - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
Construct HiveHistoryImpl object and open history log file.
HiveHistoryProxyHandler - Class in org.apache.hadoop.hive.ql.history
 
HiveHistoryProxyHandler() - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistoryProxyHandler
 
HiveHistoryUtil - Class in org.apache.hadoop.hive.ql.history
 
HiveHistoryUtil() - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistoryUtil
 
HiveHistoryViewer - Class in org.apache.hadoop.hive.ql.history
HiveHistoryViewer.
HiveHistoryViewer(String) - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistoryViewer
 
HiveIgnoreKeyTextOutputFormat<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
HiveIgnoreKeyTextOutputFormat replaces key with null before feeding the to TextOutputFormat.RecordWriter.
HiveIgnoreKeyTextOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
 
HiveIndex - Class in org.apache.hadoop.hive.ql.index
Holds index related constants
HiveIndex() - Constructor for class org.apache.hadoop.hive.ql.index.HiveIndex
 
HiveIndex.IndexType - Enum in org.apache.hadoop.hive.ql.index
 
HiveIndexedInputFormat - Class in org.apache.hadoop.hive.ql.index
Input format for doing queries that use indexes.
HiveIndexedInputFormat() - Constructor for class org.apache.hadoop.hive.ql.index.HiveIndexedInputFormat
 
HiveIndexedInputFormat(String) - Constructor for class org.apache.hadoop.hive.ql.index.HiveIndexedInputFormat
 
HiveIndexHandler - Interface in org.apache.hadoop.hive.ql.index
HiveIndexHandler defines a pluggable interface for adding new index handlers to Hive.
HiveIndexQueryContext - Class in org.apache.hadoop.hive.ql.index
Used to pass information between the IndexProcessor and the plugin IndexHandler during query processing
HiveIndexQueryContext() - Constructor for class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
HiveIndexResult - Class in org.apache.hadoop.hive.ql.index
HiveIndexResult parses the input stream from an index query to generate a list of file splits to query.
HiveIndexResult(List<String>, JobConf) - Constructor for class org.apache.hadoop.hive.ql.index.HiveIndexResult
 
HiveInputFormat<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
HiveInputFormat is a parameterized InputFormat which looks at the path name and determine the correct InputFormat for that path name from mapredPlan.pathToPartitionInfo().
HiveInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
HiveInputFormat.HiveInputSplit - Class in org.apache.hadoop.hive.ql.io
HiveInputSplit encapsulates an InputSplit with its corresponding inputFormatClass.
HiveInputFormat.HiveInputSplit() - Constructor for class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
HiveInputFormat.HiveInputSplit(InputSplit, String) - Constructor for class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
HiveJoinRel - Class in org.apache.hadoop.hive.ql.optimizer.optiq.reloperators
 
HiveJoinRel.JoinAlgorithm - Enum in org.apache.hadoop.hive.ql.optimizer.optiq.reloperators
 
HiveJoinRel.MapJoinStreamingRelation - Enum in org.apache.hadoop.hive.ql.optimizer.optiq.reloperators
 
HiveKey - Class in org.apache.hadoop.hive.ql.io
HiveKey is a simple wrapper on Text which allows us to set the hashCode easily.
HiveKey() - Constructor for class org.apache.hadoop.hive.ql.io.HiveKey
 
HiveKey(byte[], int) - Constructor for class org.apache.hadoop.hive.ql.io.HiveKey
 
HiveKey.Comparator - Class in org.apache.hadoop.hive.ql.io
A Comparator optimized for HiveKey.
HiveKey.Comparator() - Constructor for class org.apache.hadoop.hive.ql.io.HiveKey.Comparator
 
HiveLimitRel - Class in org.apache.hadoop.hive.ql.optimizer.optiq.reloperators
 
HiveLock - Class in org.apache.hadoop.hive.ql.lockmgr
 
HiveLock() - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLock
 
HiveLockManager - Interface in org.apache.hadoop.hive.ql.lockmgr
Manager for locks in Hive.
HiveLockManagerCtx - Class in org.apache.hadoop.hive.ql.lockmgr
 
HiveLockManagerCtx() - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockManagerCtx
 
HiveLockManagerCtx(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockManagerCtx
 
HiveLockMode - Enum in org.apache.hadoop.hive.ql.lockmgr
 
HiveLockObj - Class in org.apache.hadoop.hive.ql.lockmgr
 
HiveLockObj(HiveLockObject, HiveLockMode) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObj
 
HiveLockObject - Class in org.apache.hadoop.hive.ql.lockmgr
 
HiveLockObject() - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
HiveLockObject(String, HiveLockObject.HiveLockObjectData) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
HiveLockObject(String[], HiveLockObject.HiveLockObjectData) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
HiveLockObject(Table, HiveLockObject.HiveLockObjectData) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
HiveLockObject(Partition, HiveLockObject.HiveLockObjectData) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
HiveLockObject(DummyPartition, HiveLockObject.HiveLockObjectData) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
HiveLockObject.HiveLockObjectData - Class in org.apache.hadoop.hive.ql.lockmgr
 
HiveLockObject.HiveLockObjectData(String, String, String, String) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
Constructor Note: The parameters are used to uniquely identify a HiveLockObject.
HiveLockObject.HiveLockObjectData(String) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
Constructor
HiveMergeProjectRule - Class in org.apache.hadoop.hive.ql.optimizer.optiq.rules
 
HiveMergeProjectRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.rules.HiveMergeProjectRule
 
HiveMetastoreAuthenticationProvider - Interface in org.apache.hadoop.hive.ql.security
HiveMetastoreAuthenticationProvider is an interface extension from HiveAuthenticationProvider for authentication from the metastore side.
HiveMetastoreAuthorizationProvider - Interface in org.apache.hadoop.hive.ql.security.authorization
HiveMetastoreAuthorizationProvider : An extension of HiveAuthorizaytionProvider that is intended to be called from the metastore-side.
HiveMetaStoreChecker - Class in org.apache.hadoop.hive.ql.metadata
Verify that the information in the metastore matches what is on the filesystem.
HiveMetaStoreChecker(Hive) - Constructor for class org.apache.hadoop.hive.ql.metadata.HiveMetaStoreChecker
 
HiveMetastoreClientFactory - Interface in org.apache.hadoop.hive.ql.security.authorization.plugin
Factory for getting current valid instance of IMetaStoreClient Metastore client cannot be cached in authorization interface as that can get invalidated between the calls with the logic in Hive class.
HiveMetastoreClientFactoryImpl - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
Private implementaiton that returns instance of IMetaStoreClient
HiveMetastoreClientFactoryImpl() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveMetastoreClientFactoryImpl
 
HiveNullValueSequenceFileOutputFormat<K,V> - Class in org.apache.hadoop.hive.ql.io
A HiveOutputFormat that writes SequenceFiles with the content saved in the keys, and null in the values.
HiveNullValueSequenceFileOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.HiveNullValueSequenceFileOutputFormat
 
HiveOperation - Enum in org.apache.hadoop.hive.ql.plan
 
HiveOperation.PrivilegeAgreement - Class in org.apache.hadoop.hive.ql.plan
 
HiveOperation.PrivilegeAgreement() - Constructor for class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
HiveOperationType - Enum in org.apache.hadoop.hive.ql.security.authorization.plugin
List of hive operations types.
HiveOptiqUtil - Class in org.apache.hadoop.hive.ql.optimizer.optiq
Generic utility functions needed for Optiq based Hive CBO.
HiveOptiqUtil() - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.HiveOptiqUtil
 
HiveOutputFormat<K,V> - Interface in org.apache.hadoop.hive.ql.io
HiveOutputFormat describes the output-specification for Hive's operators.
HiveOutputFormatImpl<K extends org.apache.hadoop.io.WritableComparable<K>,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
Hive does not use OutputFormat's in a conventional way, but constructs and uses the defined OutputFormat for each table from FileSinkOperator.
HiveOutputFormatImpl() - Constructor for class org.apache.hadoop.hive.ql.io.HiveOutputFormatImpl
 
HivePartitioner<K2,V2> - Interface in org.apache.hadoop.hive.ql.io
Partition keys by their Object.hashCode().
HivePassThroughOutputFormat<K,V> - Class in org.apache.hadoop.hive.ql.io
This pass through class is used to wrap OutputFormat implementations such that new OutputFormats not derived from HiveOutputFormat gets through the checker
HivePassThroughOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.HivePassThroughOutputFormat
 
HivePassThroughRecordWriter<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
 
HivePassThroughRecordWriter(RecordWriter<K, V>) - Constructor for class org.apache.hadoop.hive.ql.io.HivePassThroughRecordWriter
 
HivePreWarmProcessor - Class in org.apache.hadoop.hive.ql.exec.tez
A simple sleep processor implementation that sleeps for the configured time in milliseconds.
HivePreWarmProcessor() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.HivePreWarmProcessor
 
HivePrincipal - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
Represents the user or role in grant/revoke statements
HivePrincipal(String, HivePrincipal.HivePrincipalType) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrincipal
 
HivePrincipal.HivePrincipalType - Enum in org.apache.hadoop.hive.ql.security.authorization.plugin
 
HivePrivilege - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
Represents the hive privilege being granted/revoked
HivePrivilege(String, List<String>) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilege
 
HivePrivilegeInfo - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
Represents a privilege granted for an object to a principal
HivePrivilegeInfo(HivePrincipal, HivePrivilege, HivePrivilegeObject, HivePrincipal, boolean, int) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeInfo
 
HivePrivilegeObject - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
Represents the object on which privilege is being granted/revoked
HivePrivilegeObject(HivePrivilegeObject.HivePrivilegeObjectType, String, String) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
 
HivePrivilegeObject.HivePrivilegeObjectType - Enum in org.apache.hadoop.hive.ql.security.authorization.plugin
 
HiveProjectRel - Class in org.apache.hadoop.hive.ql.optimizer.optiq.reloperators
 
HiveProjectRel(RelOptCluster, RelTraitSet, RelNode, List<RexNode>, RelDataType, int) - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveProjectRel
Creates a HiveProjectRel.
HivePullUpProjectsAboveJoinRule - Class in org.apache.hadoop.hive.ql.optimizer.optiq.rules
 
HivePullUpProjectsAboveJoinRule(RelOptRuleOperand, String) - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.rules.HivePullUpProjectsAboveJoinRule
 
HivePushJoinThroughJoinRule - Class in org.apache.hadoop.hive.ql.optimizer.optiq.rules
 
HiveRecordReader<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
HiveRecordReader is a simple wrapper on RecordReader.
HiveRecordReader(RecordReader) - Constructor for class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
HiveRecordReader(RecordReader, JobConf) - Constructor for class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
HiveRel - Interface in org.apache.hadoop.hive.ql.optimizer.optiq.reloperators
 
HiveRel.Implementor - Class in org.apache.hadoop.hive.ql.optimizer.optiq.reloperators
 
HiveRel.Implementor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveRel.Implementor
 
HiveRelMdDistinctRowCount - Class in org.apache.hadoop.hive.ql.optimizer.optiq.stats
 
HiveRelMdSelectivity - Class in org.apache.hadoop.hive.ql.optimizer.optiq.stats
 
HiveRoleGrant - Class in org.apache.hadoop.hive.ql.security.authorization.plugin
Represents a grant of a role to a principal
HiveRoleGrant() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
HiveRoleGrant(RolePrincipalGrant) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
HiveSchemaConverter - Class in org.apache.hadoop.hive.ql.io.parquet.convert
 
HiveSchemaConverter() - Constructor for class org.apache.hadoop.hive.ql.io.parquet.convert.HiveSchemaConverter
 
HiveSemanticAnalyzerHook - Interface in org.apache.hadoop.hive.ql.parse
HiveSemanticAnalyzerHook allows Hive to be extended with custom logic for semantic analysis of QL statements.
HiveSemanticAnalyzerHookContext - Interface in org.apache.hadoop.hive.ql.parse
Context information provided by Hive to implementations of HiveSemanticAnalyzerHook.
HiveSemanticAnalyzerHookContextImpl - Class in org.apache.hadoop.hive.ql.parse
 
HiveSemanticAnalyzerHookContextImpl() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
HiveSequenceFileOutputFormat<K,V> - Class in org.apache.hadoop.hive.ql.io
A HiveOutputFormat that writes SequenceFiles.
HiveSequenceFileOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
 
HiveSortRel - Class in org.apache.hadoop.hive.ql.optimizer.optiq.reloperators
 
HiveSortRel(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveSortRel
 
HiveStorageHandler - Interface in org.apache.hadoop.hive.ql.metadata
HiveStorageHandler defines a pluggable interface for adding new storage handlers to Hive.
HiveStoragePredicateHandler - Interface in org.apache.hadoop.hive.ql.metadata
HiveStoragePredicateHandler is an optional companion to HiveStorageHandler; it should only be implemented by handlers which support decomposition of predicates being pushed down into table scans.
HiveStoragePredicateHandler.DecomposedPredicate - Class in org.apache.hadoop.hive.ql.metadata
Struct class for returning multiple values from decomposePredicate.
HiveStoragePredicateHandler.DecomposedPredicate() - Constructor for class org.apache.hadoop.hive.ql.metadata.HiveStoragePredicateHandler.DecomposedPredicate
 
HiveSwapJoinRule - Class in org.apache.hadoop.hive.ql.optimizer.optiq.rules
 
HiveTableScanRel - Class in org.apache.hadoop.hive.ql.optimizer.optiq.reloperators
Relational expression representing a scan of a HiveDB collection.
HiveTableScanRel(RelOptCluster, RelTraitSet, RelOptHiveTable, RelDataType) - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveTableScanRel
Creates a HiveTableScan.
HiveTotalOrderPartitioner - Class in org.apache.hadoop.hive.ql.exec
 
HiveTotalOrderPartitioner() - Constructor for class org.apache.hadoop.hive.ql.exec.HiveTotalOrderPartitioner
 
HiveTxnManager - Interface in org.apache.hadoop.hive.ql.lockmgr
An interface that allows Hive to manage transactions.
HiveUtils - Class in org.apache.hadoop.hive.ql.metadata
General collection of helper functions.
HIVEVAR_PREFIX - Static variable in class org.apache.hadoop.hive.ql.processors.SetProcessor
 
HiveVolcanoPlanner - Class in org.apache.hadoop.hive.ql.optimizer.optiq.cost
Refinement of VolcanoPlanner for Hive.
HiveVolcanoPlanner() - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveVolcanoPlanner
Creates a HiveVolcanoPlanner.
hm - Variable in class org.apache.hadoop.hive.ql.history.HiveHistory.QueryInfo
 
hm - Variable in class org.apache.hadoop.hive.ql.history.HiveHistory.TaskInfo
 
Hook - Interface in org.apache.hadoop.hive.ql.hooks
The new interface for all the pre execute hooks and post execute hooks
hook - Variable in enum org.apache.hadoop.hive.ql.session.SessionState.ResourceType
 
HookContext - Class in org.apache.hadoop.hive.ql.hooks
Hook Context keeps all the necessary information for all the hooks.
HookContext(QueryPlan, HiveConf) - Constructor for class org.apache.hadoop.hive.ql.hooks.HookContext
 
HookContext(QueryPlan, HiveConf, Map<String, ContentSummary>) - Constructor for class org.apache.hadoop.hive.ql.hooks.HookContext
 
HookContext.HookType - Enum in org.apache.hadoop.hive.ql.hooks
 
HookUtils - Class in org.apache.hadoop.hive.ql.hooks
 
HookUtils() - Constructor for class org.apache.hadoop.hive.ql.hooks.HookUtils
 
hostname() - Static method in class org.apache.hadoop.hive.ql.txn.compactor.Worker
Get the hostname that this worker is run on.

I

IDecimalInExpr - Interface in org.apache.hadoop.hive.ql.exec.vector.expressions
 
IdentityExpression - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
An expression representing a column, only children are evaluated.
IdentityExpression() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IdentityExpression
 
IdentityExpression(int, String) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IdentityExpression
 
IDoubleInExpr - Interface in org.apache.hadoop.hive.ql.exec.vector.expressions
Interface used for both filter and non-filter versions of IN to simplify VectorizationContext code.
IfExprStringColumnStringColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprStringColumnStringColumn(int, int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringColumn
 
IfExprStringColumnStringColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringColumn
 
IfExprStringColumnStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Compute IF(expr1, expr2, expr3) for 3 input expressions.
IfExprStringColumnStringScalar(int, int, byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringScalar
 
IfExprStringColumnStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringScalar
 
IfExprStringScalarStringColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprStringScalarStringColumn(int, byte[], int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringColumn
 
IfExprStringScalarStringColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringColumn
 
IfExprStringScalarStringScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Compute IF(expr1, expr2, expr3) for 3 input column expressions.
IfExprStringScalarStringScalar(int, byte[], byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringScalar
 
IfExprStringScalarStringScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringScalar
 
ifHasTransformOrUDTF() - Method in class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
ifRetryCmdWhenFail() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
IgnoreKeyTextOutputFormat<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
Deprecated. use HiveIgnoreKeyTextOutputFormat instead}
IgnoreKeyTextOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.IgnoreKeyTextOutputFormat
Deprecated.  
ILongInExpr - Interface in org.apache.hadoop.hive.ql.exec.vector.expressions
Interface used for both filter and non-filter versions of IN to simplify VectorizationContext code.
implement(HiveRel.Implementor) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveAggregateRel
 
implement(HiveRel.Implementor) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveFilterRel
 
implement(HiveRel.Implementor) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveJoinRel
 
implement(HiveRel.Implementor) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveLimitRel
 
implement(HiveRel.Implementor) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveProjectRel
 
implement(HiveRel.Implementor) - Method in interface org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveRel
 
implement(HiveRel.Implementor) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveSortRel
 
implement(HiveRel.Implementor) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveTableScanRel
 
implicitConvertable(PrimitiveObjectInspector.PrimitiveCategory, PrimitiveObjectInspector.PrimitiveCategory) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
implicitConvertable(TypeInfo, TypeInfo) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether it is possible to implicitly convert an object of Class from to Class to.
impliesOrder(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Both UDF and UDAF functions can imply order for analytical functions
ImportSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
ImportSemanticAnalyzer.
ImportSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.ImportSemanticAnalyzer
 
in(String, Object...) - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Builder
Add an in leaf to the current item on the stack.
in - Variable in class org.apache.hadoop.hive.ql.session.SessionState
Streams to read/write from.
incCurJobNo(int) - Method in class org.apache.hadoop.hive.ql.DriverContext
 
include(boolean[]) - Method in class org.apache.hadoop.hive.ql.io.orc.Reader.Options
Set the list of columns to read.
increaseBufferSpace(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
Increase buffer space enough to accommodate next element.
incrementJoinCount(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
INDENT - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
INDEX - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
INDEX_TABLE_CREATETIME - Static variable in class org.apache.hadoop.hive.ql.index.HiveIndex
 
IndexMetadataChangeTask - Class in org.apache.hadoop.hive.ql.index
 
IndexMetadataChangeTask() - Constructor for class org.apache.hadoop.hive.ql.index.IndexMetadataChangeTask
 
IndexMetadataChangeWork - Class in org.apache.hadoop.hive.ql.index
 
IndexMetadataChangeWork() - Constructor for class org.apache.hadoop.hive.ql.index.IndexMetadataChangeWork
 
IndexMetadataChangeWork(HashMap<String, String>, String, String) - Constructor for class org.apache.hadoop.hive.ql.index.IndexMetadataChangeWork
 
indexOf(Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
indexOf(ExprNodeDesc, List<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
 
IndexPredicateAnalyzer - Class in org.apache.hadoop.hive.ql.index
IndexPredicateAnalyzer decomposes predicates, separating the parts which can be satisfied by an index from the parts which cannot.
IndexPredicateAnalyzer() - Constructor for class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
 
IndexSearchCondition - Class in org.apache.hadoop.hive.ql.index
IndexSearchCondition represents an individual search condition found by IndexPredicateAnalyzer.
IndexSearchCondition(ExprNodeColumnDesc, String, ExprNodeConstantDesc, ExprNodeGenericFuncDesc) - Constructor for class org.apache.hadoop.hive.ql.index.IndexSearchCondition
Constructs a search condition, which takes the form
IndexUpdater - Class in org.apache.hadoop.hive.ql.parse
 
IndexUpdater(List<LoadTableDesc>, Set<ReadEntity>, Configuration) - Constructor for class org.apache.hadoop.hive.ql.parse.IndexUpdater
 
IndexUpdater(LoadTableDesc, Set<ReadEntity>, Configuration) - Constructor for class org.apache.hadoop.hive.ql.parse.IndexUpdater
 
IndexUtils - Class in org.apache.hadoop.hive.ql.optimizer
Utility class for index support.
IndexWhereProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.physical.index
 
IndexWhereProcCtx(Task<? extends Serializable>, ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.index.IndexWhereProcCtx
 
IndexWhereProcessor - Class in org.apache.hadoop.hive.ql.optimizer.physical.index
IndexWhereProcessor.
IndexWhereProcessor(Map<Table, List<Index>>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.index.IndexWhereProcessor
 
IndexWhereResolver - Class in org.apache.hadoop.hive.ql.optimizer.physical
 
IndexWhereResolver() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.IndexWhereResolver
 
IndexWhereTaskDispatcher - Class in org.apache.hadoop.hive.ql.optimizer.physical.index
IndexWhereTaskDispatcher.
IndexWhereTaskDispatcher(PhysicalContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.index.IndexWhereTaskDispatcher
 
info - Variable in class org.apache.hadoop.hive.ql.session.SessionState
 
init() - Method in class org.apache.hadoop.hive.ql.Driver
 
init(String, JobConf) - Method in interface org.apache.hadoop.hive.ql.exec.errors.ErrorHeuristic
Initialize this error heuristic.
init(String, JobConf) - Method in class org.apache.hadoop.hive.ql.exec.errors.MapAggrMemErrorHeuristic
 
init(String, JobConf) - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
init(ExecMapperContext, Configuration, MapJoinOperator) - Method in interface org.apache.hadoop.hive.ql.exec.HashTableLoader
 
init(boolean, JobConf) - Static method in class org.apache.hadoop.hive.ql.exec.MapredContext
 
init(ExecMapperContext, Configuration, MapJoinOperator) - Method in class org.apache.hadoop.hive.ql.exec.mr.HashTableLoader
 
init(ExecMapperContext, Configuration, MapJoinOperator) - Method in class org.apache.hadoop.hive.ql.exec.tez.HashTableLoader
 
init() - Method in interface org.apache.hadoop.hive.ql.exec.UDAFEvaluator
Initializer.
init() - Method in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
 
init() - Method in class org.apache.hadoop.hive.ql.exec.vector.ColumnVector
Initialize the column vector.
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorAggregateExpression
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFAvgDecimal
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCount
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCountStar
 
init(AggregationDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFSumDecimal
 
init() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
init(Configuration, String, StructObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatchCtx
Initializes the VectorizedRowBatch context based on an arbitrary object inspector Used by non-tablescan operators when they change the vectorization context
init(Configuration, FileSplit) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatchCtx
Initializes VectorizedRowBatch context based on the split and Hive configuration (Job conf with hive Plan).
init(Configuration, Map<String, String>, MessageType) - Method in class org.apache.hadoop.hive.ql.io.parquet.read.DataWritableReadSupport
It creates the readContext for Parquet side with the requested schema during the init phase.
init(Configuration) - Method in class org.apache.hadoop.hive.ql.io.parquet.write.DataWritableWriteSupport
 
init() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
init() - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
init(HiveConf, SessionState.LogHelper, Hive) - Method in class org.apache.hadoop.hive.ql.parse.TaskCompiler
 
init(HiveConf, SessionState.LogHelper, Hive) - Method in class org.apache.hadoop.hive.ql.parse.TezCompiler
 
init() - Method in class org.apache.hadoop.hive.ql.processors.AddResourceProcessor
 
init() - Method in interface org.apache.hadoop.hive.ql.processors.CommandProcessor
 
init() - Method in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
init() - Method in class org.apache.hadoop.hive.ql.processors.DeleteResourceProcessor
 
init() - Method in class org.apache.hadoop.hive.ql.processors.DfsProcessor
 
init() - Method in class org.apache.hadoop.hive.ql.processors.ResetProcessor
 
init() - Method in class org.apache.hadoop.hive.ql.processors.SetProcessor
 
init(Configuration) - Method in class org.apache.hadoop.hive.ql.security.authorization.DefaultHiveAuthorizationProvider
 
init(Configuration) - Method in class org.apache.hadoop.hive.ql.security.authorization.DefaultHiveMetastoreAuthorizationProvider
 
init(Configuration) - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
 
init(Configuration) - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider
 
init(Configuration) - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsPublisher
 
init(Configuration) - Method in class org.apache.hadoop.hive.ql.stats.fs.FSStatsPublisher
 
init(Configuration) - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsPublisher
Initialize the intermediate stats DB for the first time it is running (e.g., creating tables.).
init(Configuration) - Method in interface org.apache.hadoop.hive.ql.stats.StatsPublisher
This method does the necessary one-time initializations, possibly creating the tables and database (if not exist).
init(MetaStoreThread.BooleanPointer) - Method in class org.apache.hadoop.hive.ql.txn.compactor.Initiator
 
init(MetaStoreThread.BooleanPointer) - Method in class org.apache.hadoop.hive.ql.txn.compactor.Worker
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCumeDist.GenericUDAFCumeDistEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Initialize the evaluator.
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEWAHBitmap.GenericUDAFEWAHBitmapEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFFirstValue.GenericUDAFFirstValueEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLastValue.GenericUDAFLastValueEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMkCollectionEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFNTile.GenericUDAFNTileEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFMultiplePercentileApproxEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFSinglePercentileApproxEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentRank.GenericUDAFPercentRankEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank.GenericUDAFRankEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRowNumber.GenericUDAFRowNumberEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumDouble
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumHiveDecimal
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumLong
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance.GenericUDAFVarianceEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongArrayEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator
 
initBuffer(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
You must call initBuffer first before using setVal().
initBuffer() - Method in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
Initialize buffer to default size.
initCtx(Context) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
initialize(InputStream, Configuration, Properties) - Method in class org.apache.hadoop.hive.ql.exec.BinaryRecordReader
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.ColumnStatsTask
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.DDLTask
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.ql.exec.DefaultFetchFormatter
 
initialize(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeColumnEvaluator
 
initialize(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeConstantEvaluator
 
initialize(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
Initialize should be called once and only once.
initialize(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluatorHead
 
initialize(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluatorRef
 
initialize(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeFieldEvaluator
 
initialize(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeGenericFuncEvaluator
 
initialize(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeNullEvaluator
 
initialize(Configuration, Properties) - Method in interface org.apache.hadoop.hive.ql.exec.FetchFormatter
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.ql.exec.FetchFormatter.ThriftFormatter
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.FunctionTask
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
Initialization when invoked from QL.
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
initialize(Configuration, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Initializes operators only if all parents have been initialized.
initialize(InputStream, Configuration, Properties) - Method in interface org.apache.hadoop.hive.ql.exec.RecordReader
 
initialize(OutputStream, Configuration) - Method in interface org.apache.hadoop.hive.ql.exec.RecordWriter
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.StatsNoJobTask
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
initialize(InputStream, Configuration, Properties) - Method in class org.apache.hadoop.hive.ql.exec.TextRecordReader
 
initialize(OutputStream, Configuration) - Method in class org.apache.hadoop.hive.ql.exec.TextRecordWriter
 
initialize(EdgeManagerContext) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionEdge
 
initialize(VertexManagerPluginContext) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionVertex
 
initialize(TezProcessorContext) - Method in class org.apache.hadoop.hive.ql.exec.tez.HivePreWarmProcessor
 
initialize(TezProcessorContext) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezProcessor
 
initialize(int, float, boolean, TopNHash.BinaryCollector) - Method in class org.apache.hadoop.hive.ql.exec.TopNHash
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSerde
 
initialize(Configuration, Properties) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.BlockMergeTask
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanTask
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateTask
 
initialize(HiveConf) - Method in class org.apache.hadoop.hive.ql.optimizer.Optimizer
Create the list of transformations.
initialize(HiveConf) - Method in class org.apache.hadoop.hive.ql.optimizer.PreCBOOptimizer
Create the list of transformations.
initialize() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.AbstractGenericUDFEWAHBitmapBop
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
Initialize this GenericUDF.
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFAbs
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFArray
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFArrayContains
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFAssertTrue
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNumeric
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBasePad
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseTrim
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseUnary
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBetween
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCase
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCoalesce
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcat
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcatWS
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDate
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateAdd
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateDiff
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateSub
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFDecode
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFElt
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFEncode
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFEWAHBitmapEmpty
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFField
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFloorCeilBase
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFormatNumber
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFFromUtcTimestamp
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFHash
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIf
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIn
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIndex
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFInFile
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFInstr
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLocate
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLower
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMap
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMapKeys
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMapValues
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFNamedStruct
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFNvl
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPAnd
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNot
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotNull
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNull
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPOr
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPower
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFPrintf
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFReflect
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFReflect2
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFRound
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSentences
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSize
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSortArray
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSplit
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStringToMap
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStruct
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTimestamp
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToBinary
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToChar
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToDate
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToDecimal
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToUnixTimeStamp
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToVarchar
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTranslate
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUnion
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUpper
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFWhen
 
initialize(StructObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTF
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTF
Deprecated. 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFExplode
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFInline
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFJSONTuple
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFParseUrlTuple
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFPosExplode
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFStack
 
initialize(int, int, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Sets the 'k' and 'pf' parameters.
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.UDFCurrentDB
 
initialize(HiveConf, PTFDesc, PartitionedTableFunctionDef) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
 
initialize(PTFDesc, PartitionedTableFunctionDef, TableFunctionEvaluator) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.xml.GenericUDFXPath
 
initializeAndFoldConstants(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
Initialize this GenericUDF.
initializeAsRoot(Configuration, MapWork) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
Initializes this map op as the root of the tree.
initializeBuffer(JobConf, RecordReader, int, WritableComparable, Writable) - Method in class org.apache.hadoop.hive.ql.exec.FooterBuffer
Initialize footer buffer in order to keep footer records at the end of file.
initializeForFetch() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsWork
 
initializeForFetch() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
initializeLocalWork(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
initializeLocalWork(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
initializeMapredLocalWork(MapJoinDesc, Configuration, MapredLocalWork, Log) - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator
 
initializeOutputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.Noop.NoopResolver
 
initializeOutputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMap.NoopWithMapResolver
 
initializeOutputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
This method is invoked during runtime(during deserialization of theQueryDef).
initializeOutputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.WindowingTableFunctionResolver
 
initializePTFChain(PartitionedTableFunctionDef) - Method in class org.apache.hadoop.hive.ql.plan.PTFDeserializer
 
initializeRawInputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMap.NoopWithMapResolver
 
initializeRawInputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
 
initializeVertexConf(JobConf, BaseWork) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
Creates and initializes the JobConf object for a given BaseWork object.
initializeWindowing(WindowTableFunctionDef) - Method in class org.apache.hadoop.hive.ql.plan.PTFDeserializer
 
Initiator - Class in org.apache.hadoop.hive.ql.txn.compactor
A class to initiate compactions.
Initiator() - Constructor for class org.apache.hadoop.hive.ql.txn.compactor.Initiator
 
initiliaze(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
initIOContext(long, boolean, Path) - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
initIOContext(FileSplit, JobConf, Class) - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
initIOContext(FileSplit, JobConf, Class, RecordReader) - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
initIOContextSortedProps(FileSplit, RecordReader, JobConf) - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
initNDVEstimator(GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator.DecimalStatsAgg, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator
 
initNDVEstimator(GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.DoubleStatsAgg, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator
 
initNDVEstimator(GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.LongStatsAgg, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator
 
initNDVEstimator(GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator
 
initOperatorId() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
initOutputNullsToFalse(ColumnVector, boolean, boolean, int[], int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NullUtil
 
initParseCtx(ParseContext) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
initPhase1Ctx() - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
initPlan(ReduceSinkOperator, GenMRProcContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Initialize the current plan by adding it to root tasks.
initSpillTables(JoinDesc, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
initUnionPlan(ReduceSinkOperator, UnionOperator, GenMRProcContext, Task<? extends Serializable>) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Initialize the current union plan.
initUnionPlan(GenMRProcContext, UnionOperator, Task<? extends Serializable>, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
initValue(Object) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriter
 
INNER_JOIN - Static variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
INPUT_SEPERATOR - Static variable in class org.apache.hadoop.hive.ql.io.rcfile.merge.BlockMergeTask
 
INPUT_SEPERATOR - Static variable in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanTask
 
INPUT_SUMMARY - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
InputEstimator - Interface in org.apache.hadoop.hive.ql.metadata
 
InputEstimator.Estimation - Class in org.apache.hadoop.hive.ql.metadata
 
InputEstimator.Estimation(int, long) - Constructor for class org.apache.hadoop.hive.ql.metadata.InputEstimator.Estimation
 
inputFileChanged() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
For CompbineFileInputFormat, the mapper's input file will be changed on the fly, and the input file name is passed to jobConf by shims/initNextRecordReader.
InputFormatChecker - Interface in org.apache.hadoop.hive.ql.io
Check for validity of the input files.
inputFormatClassName() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
inputFormatClassName() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns the inputFormat class name for the i-th chunk.
inputFormatClassName() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
InputMerger - Class in org.apache.hadoop.hive.ql.exec.tez.tools
A KeyValuesReader implementation that returns a sorted stream of key-values by doing a sorted merge of the key-value in LogicalInputs.
InputMerger(List<? extends Input>) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.tools.InputMerger
 
inputs - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
inputs - Variable in class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 
InputSignature - Class in org.apache.hadoop.hive.ql.parse
The input signature of a function or operator.
InputSignature(String) - Constructor for class org.apache.hadoop.hive.ql.parse.InputSignature
 
InputSignature(String, TypeInfo...) - Constructor for class org.apache.hadoop.hive.ql.parse.InputSignature
 
InputSignature(String, Class<?>...) - Constructor for class org.apache.hadoop.hive.ql.parse.InputSignature
 
inSample(Object) - Method in class org.apache.hadoop.hive.ql.metadata.Sample
Given an arbitrary object, determine if it falls within this sample.
insert(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CuckooSetBytes
 
insert(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CuckooSetDouble
Insert a single value into the set.
insert(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CuckooSetLong
 
insert(long, Object) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater
 
insert(long, Object) - Method in interface org.apache.hadoop.hive.ql.io.RecordUpdater
Insert a new record into the table.
INSERT - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
inspector(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
Use the given ObjectInspector for each record written.
inspector(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
A required option that sets the object inspector for the rows.
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.optiq.HiveDefaultRelMetadataProvider
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.optiq.rules.HiveMergeProjectRule
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.optiq.rules.HiveSwapJoinRule
 
IntegerColumnStatistics - Interface in org.apache.hadoop.hive.ql.io.orc
Statistics for all of the integer columns, such as byte, short, int, and long.
IntraQueryCorrelation - Class in org.apache.hadoop.hive.ql.optimizer.correlation
IntraQueryCorrelation records a sub-tree of the query plan tree which can be evaluated in a single MR job.
IntraQueryCorrelation(int) - Constructor for class org.apache.hadoop.hive.ql.optimizer.correlation.IntraQueryCorrelation
 
InvalidTableException - Exception in org.apache.hadoop.hive.ql.metadata
Generic exception class for Hive.
InvalidTableException(String) - Constructor for exception org.apache.hadoop.hive.ql.metadata.InvalidTableException
 
invoke(Method, Object, Object...) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
invoke(Object, Method, Object[]) - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryProxyHandler
 
invokeRewriteQueryProc(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
Walk the original operator tree using the DefaultGraphWalker using the rules.
IO_TMP_DIR - Static variable in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
IOConstants - Class in org.apache.hadoop.hive.ql.io
 
IOContext - Class in org.apache.hadoop.hive.ql.io
IOContext basically contains the position information of the current key/value.
IOContext() - Constructor for class org.apache.hadoop.hive.ql.io.IOContext
 
IOContext.Comparison - Enum in org.apache.hadoop.hive.ql.io
 
IOPrepareCache - Class in org.apache.hadoop.hive.ql.io
IOPrepareCache is used to cache pre-query io-related objects.
IOPrepareCache() - Constructor for class org.apache.hadoop.hive.ql.io.IOPrepareCache
 
isAbort() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapper
 
isAggFuncColsFetchException() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
isAggFuncIsNotCount() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
isAllColumns() - Method in interface org.apache.hadoop.hive.ql.udf.generic.GenericUDAFParameterInfo
Returns true if the UDAF invocation was done via the wildcard syntax FUNCTION(*).
isAllColumns() - Method in class org.apache.hadoop.hive.ql.udf.generic.SimpleGenericUDAFParameterInfo
 
isAllInputsInSameReducer() - Method in class org.apache.hadoop.hive.ql.plan.UnionDesc
 
isAllTrue(boolean[]) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
isAnalyzeCommand() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
isAnalyzeRewrite() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
isAppendTaskType() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
isArchived(Partition) - Static method in class org.apache.hadoop.hive.ql.exec.ArchiveUtils
Determines whether a partition has been archived
isAuthorizationModeV2() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
isAvailable() - Method in interface org.apache.hadoop.hive.ql.io.orc.DirectDecompressionCodec
 
isBigTablePartitioned() - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
isBinarySearching() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
isBlockPointer() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
isBucketMapJoin() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
isCandidate(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Returns true if the specified expression is pushdown candidate else false.
isCarryForwardNames() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
isCasdade() - Method in class org.apache.hadoop.hive.ql.plan.DropDatabaseDesc
 
isCastToFloatFamily(Class<? extends UDF>) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isCastToIntFamily(Class<? extends UDF>) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isClearAggregatorStats() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
isComplete() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
isCompressed(boolean) - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
Should the output be compressed?
isCompressed() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
isCompressedRCFile() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
 
isConstant() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
isConvertedAutomaticallySMBJoin() - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
isCountOfOne() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
isCountOnAllCols() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
isCTAS() - Method in class org.apache.hadoop.hive.ql.parse.QB
Whether this QB is for a CREATE-TABLE-AS-SELECT.
isCustomUDF(ExprNodeGenericFuncDesc) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isDateFamily(String) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isDatetimeFamily(String) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isDecimalFamily(String) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isDefault() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
isDeferredRebuild() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
isDeterministic() - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
Return whether this node (and all children nodes) are deterministic.
isDeterministic() - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeGenericFuncEvaluator
 
isDeterministic(GenericUDF) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether a GenericUDF is deterministic or not.
isDeterministic(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
Return false if the expression has any non determinitic function
isDeterministic() - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
isDeterministic() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
isDirect() - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
isDistinct() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFunctionSpec
 
isDistinct() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
isDistinct() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
isDistinct() - Method in interface org.apache.hadoop.hive.ql.udf.generic.GenericUDAFParameterInfo
Returns true if the UDAF invocation was qualified with DISTINCT keyword.
isDistinct() - Method in class org.apache.hadoop.hive.ql.udf.generic.SimpleGenericUDAFParameterInfo
 
isDistinctLike() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
Checks if this grouping is like distinct, which means that all non-distinct grouping columns behave like they were distinct - for example min and max operators.
isDontResetAggrsDistinct() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
isDummy() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
isDummyTable() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isEligibleForLocalMode(HiveConf, int, long, long) - Static method in class org.apache.hadoop.hive.ql.exec.mr.MapRedTask
Find out if a job can be run in local mode based on it's characteristics
isEmptyPath(JobConf, Path, Context) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
isEmptyPath(JobConf, Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
isEmptyTable() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
isEnable() - Method in class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
isEqual(Object, Object) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.DoubleValueBoundaryScanner
 
isEqual(Object, Object) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.LongValueBoundaryScanner
 
isEqual(Object, Object) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.StringValueBoundaryScanner
 
isEqWithEpsilon(RelOptCost) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCost
 
isErrorOnSrcEmpty() - Method in class org.apache.hadoop.hive.ql.plan.CopyWork
 
isEstimable(GenericUDAFEvaluator.AggregationBuffer) - Static method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
 
ISetDoubleArg - Interface in org.apache.hadoop.hive.ql.exec.vector.expressions
 
ISetLongArg - Interface in org.apache.hadoop.hive.ql.exec.vector.expressions
 
isExactNumericType(PrimitiveTypeInfo) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Check if a type is exact (not approximate such as float and double).
isExplain() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
isExt() - Method in class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
isExt() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
isExt() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
isExtended() - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
isExternal() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
isExternal() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
isFetchingTable() - Method in class org.apache.hadoop.hive.ql.Driver
 
isFinalMapRed() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
isFixedAsSorted() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
isFloatFamily(String) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isFollowedByGroupBy() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
isFormatted() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
isFormatted() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
isFormatted() - Method in class org.apache.hadoop.hive.ql.plan.ShowIndexesDesc
 
isGatheringStats() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
isGatheringStats() - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanWork
 
isGatheringStats() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
isGatheringStats() - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
isGatherStats() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
isGatherStats() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
isGbyKeysFetchException() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
isGenericUDAF() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
isGenericUDF() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
isGenericUDTF() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
isGrantOption() - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
isGrantOption() - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
isGrantOption() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeInfo
 
isGrantOption() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
isGreater(Object, Object, int) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.DoubleValueBoundaryScanner
 
isGreater(Object, Object, int) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.LongValueBoundaryScanner
 
isGreater(Object, Object, int) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.StringValueBoundaryScanner
 
isGroupingSetsPresent() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
isHandleSkewJoin() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
isHasMapGroupBy() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
isHDFSCleanup() - Method in class org.apache.hadoop.hive.ql.Context
 
isHidden() - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
isHiddenVirtualCol() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
isHiveServerQuery() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
isIfNotExists() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
isImmutable() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isImpliesOrder() - Method in class org.apache.hadoop.hive.ql.exec.WindowFunctionInfo
 
isIndexTable() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isInfinite() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCost
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Returns true if the 'k' and 'pf' parameters have been set.
isInputCached(String) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezCacheAccess
 
isInputFormatSorted() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
isInsertInto(ParseContext, FileSinkOperator) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Returns true iff current query is an insert into for the given file sink
isInsertIntoTable(String, String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
isInsertToTable() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
isInternalTableFunction() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
Internal table functions cannot be used in the language.
isIntFamily(String) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isJoinToken(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.ParseUtils
Tests whether the parse tree node is a join token.
isKey(BitSet) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.RelOptHiveTable
 
isLaunchable(Task<? extends Serializable>) - Static method in class org.apache.hadoop.hive.ql.DriverContext
Checks if a task can be launched.
isLe(RelOptCost) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCost
 
isLinkedFileSink() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
isListBucketingAlterTableConcatenate() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
isListBucketingAlterTableConcatenate() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
isListBucketingPart(Partition) - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPrunerUtils
check if the partition is list bucketing
isLocal() - Method in class org.apache.hadoop.hive.ql.exec.MoveTask
 
isLocalMode() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
isLocalOnlyExecutionMode() - Method in class org.apache.hadoop.hive.ql.Context
Does Hive wants to run tasks entirely on the local machine (where the query is being compiled)? Today this translates into running hadoop jobs locally
isLogical() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
isLt(RelOptCost) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCost
 
isMap() - Method in class org.apache.hadoop.hive.ql.exec.MapredContext
Returns whether the UDF is called from Map or Reduce task.
isMapGroupBy() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
isMapJoinRemoved() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
isMapOnlySubq() - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext
 
isMapperCannotSpanPartns() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
isMapRedLocalTask() - Method in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
isMapRedLocalTask() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
isMapRedTask() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
isMapRedTask() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
isMapRedTask() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
isMapRedTask() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezTask
 
isMapSide() - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
isMapSideJoin() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
isMergeRequired(List<Task<MoveWork>>, HiveConf, FileSinkOperator, Task<? extends Serializable>, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Returns true iff the fsOp requires a merge
isMRTmpFileURI(String) - Method in class org.apache.hadoop.hive.ql.Context
Check if path is for intermediate data
isMultiFileSpray() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
isNative() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
Native functions cannot be unregistered.
isNativeFuncExpr(ExprNodeGenericFuncDesc) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
isNeeded() - Method in enum org.apache.hadoop.hive.ql.io.sarg.SearchArgument.TruthValue
Does the RecordReader need to include this set of records?
isNeedLockMgr() - Method in class org.apache.hadoop.hive.ql.Context
 
isNewFormat() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
isNil() - Method in class org.apache.hadoop.hive.ql.parse.ASTErrorNode
 
isNonNative() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isNonNative() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
isNonVectorizedPathUDF(ExprNodeGenericFuncDesc) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isNoOuterJoin() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
isNoOuterJoin() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
isNoScanAnalyzeCommand() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
isNoScanAnalyzeCommand() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
IsNotNull - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This expression evaluates to true if the given input columns is not null.
IsNotNull(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNotNull
 
IsNotNull() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNotNull
 
isNotPartitioned() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
isNull - Variable in class org.apache.hadoop.hive.ql.exec.vector.ColumnVector
 
IsNull - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This expression evaluates to true if the given input columns is null.
IsNull(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNull
 
IsNull() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNull
 
isNull(String) - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Builder
Add an is null leaf to the current item on the stack.
isNumericType(PrimitiveTypeInfo) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Check if the given type is numeric.
isOffline() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
isOffline() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isOpAnd(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether the exprNodeDesc is a node of "and".
isOpAndOrNot(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether the exprNodeDesc is a node of "and", "or", "not".
isOpen() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
Returns whether a session has been established
isOperator() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
isOpNot(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether the exprNodeDesc is a node of "not".
isOpOr(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether the exprNodeDesc is a node of "or".
isOpPositive(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether the exprNodeDesc is a node of "positive".
isOpPreserveInputName(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether the exprNodeDesc can recommend name for the expression
isOriginal() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcNewSplit
 
isOriginal() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSplit
 
isOuterLateralView() - Method in class org.apache.hadoop.hive.ql.plan.UDTFDesc
 
isOuterLV() - Method in class org.apache.hadoop.hive.ql.plan.UDTFDesc
 
isPartialScanAnalyzeCommand() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
isPartialScanAnalyzeCommand() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
isPartition() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DataContainer
Returns true in case this data container is a partition.
isPartitioned() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isPartitioned() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
isPartitioned() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
isPartitionKey(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isPivotResult() - Method in class org.apache.hadoop.hive.ql.exec.WindowFunctionInfo
 
isPivotResult() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
isPositive() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
isPretty() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
isProtectModeEnable() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
isQualifiedFunctionName(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionUtils
 
isQueryHasGroupBy() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
isQueryHasMultipleTables() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
isRankingFunction(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Use this to check if function is ranking function
isReady() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Returns true if this histogram object has been initialized by calling merge() or allocate().
isRemovedReduceSinkBucketSort() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
isRepairPartitions() - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
isRepeating - Variable in class org.apache.hadoop.hive.ql.exec.vector.ColumnVector
 
isRootTask() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
isRunnable() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
isRunning() - Method in class org.apache.hadoop.hive.ql.DriverContext
 
isRunning() - Method in class org.apache.hadoop.hive.ql.exec.TaskResult
 
isRunning() - Method in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnListDesc
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeNullDesc
 
isSeenOp(Task, Operator) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
isSelClauseColsFetchException() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
isSelectStar() - Method in class org.apache.hadoop.hive.ql.plan.SelectDesc
 
isSelStarNoCompute() - Method in class org.apache.hadoop.hive.ql.plan.SelectDesc
 
isShutdown() - Method in class org.apache.hadoop.hive.ql.DriverContext
 
isSimpleSelectQuery() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
isSimpleSelectQuery() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
isSkewedCol() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
isSkewedCol() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
isSkewedStoredAsDir() - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
check if list bucketing is enabled.
isSkewedStoredAsDirs(FileSinkDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
check if it is skewed table and stored as dirs.
isSortedExpr() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
isSortedFilter() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
isStar() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFunctionSpec
 
isStar() - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
isStateful() - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
Return whether this node (or any children nodes) are stateful.
isStateful() - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeGenericFuncEvaluator
 
isStateful(GenericUDF) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether a GenericUDF is stateful or not.
isStateful() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
isStatsCollectRawDataSize() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
isStatsReliable() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
isStatsReliable() - Method in class org.apache.hadoop.hive.ql.plan.StatsNoJobWork
 
isStatsReliable() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
isStatsReliable() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
isStoredAsSubDirectories() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
isStoredAsSubDirectories() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isStoredAsSubDirectories() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
isStoredAsSubDirectories() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
isStoredAsSubDirectories() - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
isStringFamily(String) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isSubQuery() - Method in class org.apache.hadoop.hive.ql.optimizer.TezBucketJoinProcCtx
 
isSuccess() - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
isSumDefined() - Method in interface org.apache.hadoop.hive.ql.io.orc.IntegerColumnStatistics
Is the sum defined? If the sum overflowed the counter this will be false.
isSupportsWindow() - Method in class org.apache.hadoop.hive.ql.exec.WindowFunctionInfo
 
isTableFunction() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
isTableFunction(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
isTblDataDone() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
isTblLevel() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
isTblLvl() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
isTemp() - Method in class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
isTemp() - Method in class org.apache.hadoop.hive.ql.plan.DropFunctionDesc
 
isTempPath(FileStatus) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Detect if the supplied file is a temporary path.
isTempURI() - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
isTimestampFamily(String) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
isTransformsRawInput() - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
isTransformsRawInput() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
IStringInExpr - Interface in org.apache.hadoop.hive.ql.exec.vector.expressions
Interface used for both filter and non-filter versions of IN to simplify VectorizationContext code.
isTurnOffSkewed() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
isTurnOffSorting() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
isUseBucketizedHiveInputFormat() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
isUseBucketizedHiveInputFormat() - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
isUtfStartByte(byte) - Static method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils
Checks if b is the first byte of a UTF-8 character.
isValidPrefixSpec(Table, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Checks if given specification is proper specification for prefix of partition cols, for table partitioned by ds, hr, min valid ones are (ds='2008-04-08'), (ds='2008-04-08', hr='12'), (ds='2008-04-08', hr='12', min='30') invalid one is for example (ds='2008-04-08', min='30')
isValidStatistic(String) - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Check if a particular statistic type is supported
isValidStatisticSet(Collection<String>) - Static method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
Check if the set to be published is within the supported statistics.
isVariable() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
isVectorMode(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Returns true if a plan is both configured for vectorized execution and vectorization is allowed.
isView() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isWhrClauseColsFetchException() - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
isWindowsScript(File) - Static method in class org.apache.hadoop.hive.ql.util.DosToUnix
 
isWithGrant() - Method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLPrivTypeGrant
 
isWritingBase() - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
 
iterate(Collection<? extends Node>, Class<T>, NodeUtils.Function<T>) - Static method in class org.apache.hadoop.hive.ql.exec.NodeUtils
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Iterate through original data.
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEWAHBitmap.GenericUDAFEWAHBitmapEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFFirstValue.GenericUDAFFirstValueEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLastValue.GenericUDAFLastValueEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMkCollectionEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFNTile.GenericUDAFNTileEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank.GenericUDAFRankEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRowNumber.GenericUDAFRowNumberEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumDouble
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumHiveDecimal
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumLong
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance.GenericUDAFVarianceEvaluator
 
iterate(LongWritable, List<DoubleWritable>) - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongArrayEvaluator
 
iterate(LongWritable, Double) - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongEvaluator
Note that percentile can be null in a global aggregation with 0 input rows: "select percentile(col, 0.5) from t where false" In that case, iterate(null, null) will be called once.
iterate(Object) - Method in class org.apache.hadoop.hive.ql.udf.UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator
 
iterateParents(Operator<?>, NodeUtils.Function<Operator<?>>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorUtils
 
iterateTask(Collection<Task<?>>, Class<T>, NodeUtils.Function<T>) - Static method in class org.apache.hadoop.hive.ql.exec.NodeUtils
 
iterator() - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
iterator() - Method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 

J

JAVA32_ARRAY - Static variable in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
JAVA32_ARRAY_META - Static variable in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
JAVA32_META - Static variable in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
JAVA32_OBJECT - Static variable in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
JAVA32_REF - Static variable in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
JAVA64_ARRAY - Static variable in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
JAVA64_ARRAY_META - Static variable in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
JAVA64_META - Static variable in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
JAVA64_OBJECT - Static variable in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
JAVA64_REF - Static variable in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
JavaDataModel - Enum in org.apache.hadoop.hive.ql.util
Estimation of memory footprint of object
JDBCStatsAggregator - Class in org.apache.hadoop.hive.ql.stats.jdbc
 
JDBCStatsAggregator() - Constructor for class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsAggregator
 
JDBCStatsPublisher - Class in org.apache.hadoop.hive.ql.stats.jdbc
 
JDBCStatsPublisher() - Constructor for class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsPublisher
 
JDBCStatsSetupConstants - Class in org.apache.hadoop.hive.ql.stats.jdbc
 
JDBCStatsSetupConstants() - Constructor for class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsSetupConstants
 
JDBCStatsUtils - Class in org.apache.hadoop.hive.ql.stats.jdbc
 
JDBCStatsUtils() - Constructor for class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsUtils
 
jobClose(Configuration, boolean) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Unlike other operator interfaces which are called from map or reduce task, jobClose is called from the jobclient side once the job has completed.
jobClose(Path, boolean, JobConf, SessionState.LogHelper, DynamicPartitionCtx, Reporter) - Static method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileMergeMapper
 
jobClose(Path, boolean, JobConf, SessionState.LogHelper, DynamicPartitionCtx, Reporter) - Static method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateMapper
 
jobCloseOp(Configuration, boolean) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
jobCloseOp(Configuration, boolean) - Method in class org.apache.hadoop.hive.ql.exec.JoinOperator
 
jobCloseOp(Configuration, boolean) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
JobDebugger - Class in org.apache.hadoop.hive.ql.exec.mr
JobDebugger takes a RunningJob that has failed and grabs the top 4 failing tasks and outputs this information to the Hive CLI.
JobDebugger(JobConf, RunningJob, SessionState.LogHelper) - Constructor for class org.apache.hadoop.hive.ql.exec.mr.JobDebugger
 
JobDebugger(JobConf, RunningJob, SessionState.LogHelper, Map<String, List<List<String>>>) - Constructor for class org.apache.hadoop.hive.ql.exec.mr.JobDebugger
 
jobId - Variable in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
jobInfo(RunningJob) - Method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
from StreamJob.java.
JobTrackerURLResolver - Class in org.apache.hadoop.hive.ql.exec.mr
JobTrackerURLResolver.
join(String...) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
JoinCond - Class in org.apache.hadoop.hive.ql.parse
Join conditions Descriptor implementation.
JoinCond() - Constructor for class org.apache.hadoop.hive.ql.parse.JoinCond
 
JoinCond(int, int, JoinType) - Constructor for class org.apache.hadoop.hive.ql.parse.JoinCond
 
JoinCond(boolean) - Constructor for class org.apache.hadoop.hive.ql.parse.JoinCond
Constructor for a UNIQUEJOIN cond.
JoinCondDesc - Class in org.apache.hadoop.hive.ql.plan
Join conditions Descriptor implementation.
JoinCondDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
JoinCondDesc(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
JoinCondDesc(JoinCond) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
JoinDesc - Class in org.apache.hadoop.hive.ql.plan
Join operator Descriptor implementation.
JoinDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.JoinDesc
 
JoinDesc(Map<Byte, List<ExprNodeDesc>>, List<String>, boolean, JoinCondDesc[], Map<Byte, List<ExprNodeDesc>>) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinDesc
 
JoinDesc(Map<Byte, List<ExprNodeDesc>>, List<String>, boolean, JoinCondDesc[]) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinDesc
 
JoinDesc(Map<Byte, List<ExprNodeDesc>>, List<String>) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinDesc
 
JoinDesc(Map<Byte, List<ExprNodeDesc>>, List<String>, JoinCondDesc[]) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinDesc
 
JoinDesc(JoinDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinDesc
 
JoinOperator - Class in org.apache.hadoop.hive.ql.exec
Join operator implementation.
JoinOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.JoinOperator
 
JoinOperator.SkewkeyTableCounter - Enum in org.apache.hadoop.hive.ql.exec
SkewkeyTableCounter.
joinPlan(Task<? extends Serializable>, Task<? extends Serializable>, GenMRProcContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Merge the current task into the old task for the reducer
JoinReorder - Class in org.apache.hadoop.hive.ql.optimizer
Implementation of rule-based join table reordering optimization.
JoinReorder() - Constructor for class org.apache.hadoop.hive.ql.optimizer.JoinReorder
 
JoinType - Enum in org.apache.hadoop.hive.ql.parse
JoinType.
joinUnionPlan(GenMRProcContext, UnionOperator, Task<? extends Serializable>, Task<? extends Serializable>, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
JoinUtil - Class in org.apache.hadoop.hive.ql.exec
 
JoinUtil() - Constructor for class org.apache.hadoop.hive.ql.exec.JoinUtil
 
JoinUtil - Class in org.apache.hadoop.hive.ql.optimizer.optiq
Utility for inspecting Join Conditions.
JoinUtil() - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil
 
JoinUtil.JoinLeafPredicateInfo - Class in org.apache.hadoop.hive.ql.optimizer.optiq
JoinLeafPredicateInfo represents leaf predicate in Join condition (conjuctive lement).
JoinUtil.JoinLeafPredicateInfo(SqlKind, List<RexNode>, List<RexNode>, Set<Integer>, Set<Integer>, Set<Integer>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinLeafPredicateInfo
 
JoinUtil.JoinPredicateInfo - Class in org.apache.hadoop.hive.ql.optimizer.optiq
JoinPredicateInfo represents Join condition; JoinPredicate Info uses JoinLeafPredicateInfo to represent individual conjunctive elements in the predicate.
JoinPredicateInfo = JoinLeafPredicateInfo1 and JoinLeafPredicateInfo2...
JoinUtil.JoinPredicateInfo(List<JoinUtil.JoinLeafPredicateInfo>, List<JoinUtil.JoinLeafPredicateInfo>, Set<Integer>, Set<Integer>, Set<Integer>, Map<Integer, ImmutableList<JoinUtil.JoinLeafPredicateInfo>>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil.JoinPredicateInfo
 
JsonMetaDataFormatter - Class in org.apache.hadoop.hive.ql.metadata.formatting
Format table and index information for machine readability using json.
JsonMetaDataFormatter() - Constructor for class org.apache.hadoop.hive.ql.metadata.formatting.JsonMetaDataFormatter
 

K

KeyWrapper - Class in org.apache.hadoop.hive.ql.exec
 
KeyWrapper() - Constructor for class org.apache.hadoop.hive.ql.exec.KeyWrapper
 
KeyWrapperFactory - Class in org.apache.hadoop.hive.ql.exec
 
KeyWrapperFactory(ExprNodeEvaluator[], ObjectInspector[], ObjectInspector[]) - Constructor for class org.apache.hadoop.hive.ql.exec.KeyWrapperFactory
 
killRunningJobs() - Static method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 

L

l4j - Static variable in class org.apache.hadoop.hive.ql.exec.mr.ExecMapper
 
l4j - Static variable in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
l4j - Static variable in class org.apache.hadoop.hive.ql.exec.mr.ExecReducer
 
l4j - Static variable in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
l4j - Static variable in class org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor
 
l4j - Static variable in class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
l4j - Static variable in class org.apache.hadoop.hive.ql.exec.tez.ReduceRecordProcessor
 
l4j - Static variable in class org.apache.hadoop.hive.ql.exec.tez.tools.InputMerger
 
l4j - Static variable in class org.apache.hadoop.hive.ql.index.compact.HiveCompactIndexInputFormat
 
l4j - Static variable in class org.apache.hadoop.hive.ql.index.HiveIndex
 
l4j - Static variable in class org.apache.hadoop.hive.ql.index.HiveIndexedInputFormat
 
l4j - Static variable in class org.apache.hadoop.hive.ql.index.HiveIndexResult
 
LA(int) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.ANTLRNoCaseStringStream
 
lag(int) - Method in interface org.apache.hadoop.hive.ql.exec.PTFPartition.PTFPartitionIterator
 
LAG_FUNC_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
LAST_VALUE_FUNC_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
lastIndexOf(Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
lastSeenSyncPos() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Returns the last seen sync position.
LateralViewForwardDesc - Class in org.apache.hadoop.hive.ql.plan
LateralViewForwardDesc.
LateralViewForwardDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LateralViewForwardDesc
 
LateralViewForwardOperator - Class in org.apache.hadoop.hive.ql.exec
LateralViewForwardOperator.
LateralViewForwardOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.LateralViewForwardOperator
 
LateralViewJoinDesc - Class in org.apache.hadoop.hive.ql.plan
LateralViewJoinDesc.
LateralViewJoinDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LateralViewJoinDesc
 
LateralViewJoinDesc(int, ArrayList<String>) - Constructor for class org.apache.hadoop.hive.ql.plan.LateralViewJoinDesc
 
LateralViewJoinOperator - Class in org.apache.hadoop.hive.ql.exec
The lateral view join operator is used for FROM src LATERAL VIEW udtf()...
LateralViewJoinOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.LateralViewJoinOperator
 
launching(TaskRunner) - Method in class org.apache.hadoop.hive.ql.DriverContext
 
LazyFlatRowContainer - Class in org.apache.hadoop.hive.ql.exec.persistence
 
LazyFlatRowContainer() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
LBExprProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.listbucketingpruner
The processor context for list bucketing pruner.
LBExprProcCtx(String, Partition) - Constructor for class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBExprProcCtx
 
LBExprProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.listbucketingpruner
Expression processor factory for list bucketing pruning.
LBExprProcFactory.LBPRColumnExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.listbucketingpruner
Processor for lbpr column expressions.
LBExprProcFactory.LBPRColumnExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBExprProcFactory.LBPRColumnExprProcessor
 
LBOpPartitionWalkerCtx - Class in org.apache.hadoop.hive.ql.optimizer.listbucketingpruner
Context used by list bucketing pruner to get all partitions
LBOpPartitionWalkerCtx(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBOpPartitionWalkerCtx
Constructor.
LBOpWalkerCtx - Class in org.apache.hadoop.hive.ql.optimizer.listbucketingpruner
Context used by list bucketing to walk operator trees to generate expression tree.
LBOpWalkerCtx(Map<TableScanOperator, Map<String, ExprNodeDesc>>, Partition) - Constructor for class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBOpWalkerCtx
Constructor.
LBPartitionProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.listbucketingpruner
Walk through top operators in tree to find all partitions.
LBPartitionProcFactory.LBPRPartitionFilterPruner - Class in org.apache.hadoop.hive.ql.optimizer.listbucketingpruner
Retrieve partitions for the filter.
LBPartitionProcFactory.LBPRPartitionFilterPruner() - Constructor for class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBPartitionProcFactory.LBPRPartitionFilterPruner
 
LBProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.listbucketingpruner
Operator factory for list bucketing pruning processing of operator graph We find all the filter operators that appear just beneath the table scan operators.
LBProcFactory.LBPRFilterPruner - Class in org.apache.hadoop.hive.ql.optimizer.listbucketingpruner
Determines the list bucketing pruner for the filter.
LBProcFactory.LBPRFilterPruner() - Constructor for class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBProcFactory.LBPRFilterPruner
 
LBRACE - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
LBRACKET - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
lead(int) - Method in interface org.apache.hadoop.hive.ql.exec.PTFPartition.PTFPartitionIterator
 
LEAD_FUNC_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
LeadLagInfo - Class in org.apache.hadoop.hive.ql.parse
Lead Lag functionality
LeadLagInfo() - Constructor for class org.apache.hadoop.hive.ql.parse.LeadLagInfo
 
leafOperatorToFollowingWork - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
LEFT - Static variable in class org.apache.hadoop.hive.ql.optimizer.optiq.rules.HivePushJoinThroughJoinRule
 
LEFT_OUTER_JOIN - Static variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
LEFT_PROJECT - Static variable in class org.apache.hadoop.hive.ql.optimizer.optiq.rules.HivePullUpProjectsAboveJoinRule
 
LEFT_SEMI_JOIN - Static variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
LeftmostBigTableSelectorForAutoSMJ - Class in org.apache.hadoop.hive.ql.optimizer
 
LeftmostBigTableSelectorForAutoSMJ() - Constructor for class org.apache.hadoop.hive.ql.optimizer.LeftmostBigTableSelectorForAutoSMJ
 
LEGACY_BUCKET_DIGIT_PATTERN - Static variable in class org.apache.hadoop.hive.ql.io.AcidUtils
 
length - Variable in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
 
lengthFor(String) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthFor(NumericHistogram) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthFor(NumDistinctValueEstimator) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthForBooleanArrayOfSize(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthForByteArrayOfSize(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthForDateArrayOfSize(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthForDecimalArrayOfSize(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthForDoubleArrayOfSize(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthForIntArrayOfSize(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthForLongArrayOfSize(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthForObjectArrayOfSize(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthForRandom() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthForStringOfLength(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthForTimestampArrayOfSize(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthOfDate() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthOfDecimal() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lengthOfTimestamp() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
lessThan(String, Object) - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Builder
Add a less than leaf to the current item on the stack.
lessThanEquals(String, Object) - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Builder
Add a less than equals leaf to the current item on the stack.
lightEscapeString(String) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
likePatternToRegExp(String) - Static method in class org.apache.hadoop.hive.ql.udf.UDFLike
 
LimitDesc - Class in org.apache.hadoop.hive.ql.plan
LimitDesc.
LimitDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LimitDesc
 
LimitDesc(int) - Constructor for class org.apache.hadoop.hive.ql.plan.LimitDesc
 
LimitOperator - Class in org.apache.hadoop.hive.ql.exec
Limit operator implementation Limits the number of rows to be passed on.
LimitOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.LimitOperator
 
limitPrune(Partition, long, int, Collection<Path>) - Static method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner
Try to generate a list of subset of files in the partition to reach a size limit with number of files less than fileLimit
LimitPushdownOptimizer - Class in org.apache.hadoop.hive.ql.optimizer
Make RS calculate top-K selection for limit clause.
LimitPushdownOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.LimitPushdownOptimizer
 
LINE_DELIM - Static variable in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatUtils
 
LINE_SEP - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
LineageCtx - Class in org.apache.hadoop.hive.ql.optimizer.lineage
This class contains the lineage context that is passed while walking the operator tree in Lineage.
LineageCtx(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx
Constructor.
LineageCtx.Index - Class in org.apache.hadoop.hive.ql.optimizer.lineage
 
LineageCtx.Index() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx.Index
Constructor.
LineageInfo - Class in org.apache.hadoop.hive.ql.hooks
This class contains the lineage information that is passed to the PreExecution hook.
LineageInfo() - Constructor for class org.apache.hadoop.hive.ql.hooks.LineageInfo
Constructor.
LineageInfo - Class in org.apache.hadoop.hive.ql.tools
This class prints out the lineage info.
LineageInfo() - Constructor for class org.apache.hadoop.hive.ql.tools.LineageInfo
 
LineageInfo.BaseColumnInfo - Class in org.apache.hadoop.hive.ql.hooks
Base Column information.
LineageInfo.BaseColumnInfo() - Constructor for class org.apache.hadoop.hive.ql.hooks.LineageInfo.BaseColumnInfo
 
LineageInfo.DataContainer - Class in org.apache.hadoop.hive.ql.hooks
Table or Partition data container.
LineageInfo.DataContainer(Table) - Constructor for class org.apache.hadoop.hive.ql.hooks.LineageInfo.DataContainer
Constructor for non partitioned tables.
LineageInfo.DataContainer(Table, Partition) - Constructor for class org.apache.hadoop.hive.ql.hooks.LineageInfo.DataContainer
Constructor for a partitioned tables partition.
LineageInfo.Dependency - Class in org.apache.hadoop.hive.ql.hooks
This class tracks the dependency information for the base column.
LineageInfo.Dependency() - Constructor for class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
LineageInfo.DependencyKey - Class in org.apache.hadoop.hive.ql.hooks
Class that captures the lookup key for the dependency.
LineageInfo.DependencyKey(LineageInfo.DataContainer, FieldSchema) - Constructor for class org.apache.hadoop.hive.ql.hooks.LineageInfo.DependencyKey
Constructor.
LineageInfo.DependencyType - Enum in org.apache.hadoop.hive.ql.hooks
Enum to track dependency.
LineageInfo.TableAliasInfo - Class in org.apache.hadoop.hive.ql.hooks
 
LineageInfo.TableAliasInfo() - Constructor for class org.apache.hadoop.hive.ql.hooks.LineageInfo.TableAliasInfo
 
LineageState - Class in org.apache.hadoop.hive.ql.session
LineageState.
LineageState() - Constructor for class org.apache.hadoop.hive.ql.session.LineageState
Constructor.
linkChildOpWithDummyOp - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
linkedFileSinks - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
linkedHashMap(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
linkedList(int) - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
linkMoveTask(FileSinkOperator, ConditionalTask, List<Task<MoveWork>>, HiveConf, DependencyCollectionTask) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Make the move task in the GenMRProcContext following the FileSinkOperator a dependent of all possible subtrees branching from the ConditionalTask.
linkMoveTask(Task<MoveWork>, Task<? extends Serializable>, HiveConf, DependencyCollectionTask) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Follows the task tree down from task and makes all leaves parents of mvTask
linkOpWithWorkMap - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
linkWorkWithReduceSinkMap - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
list() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
list_resource(SessionState.ResourceType, List<String>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
ListBucketingCtx - Class in org.apache.hadoop.hive.ql.plan
Context for list bucketing.
ListBucketingCtx() - Constructor for class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
ListBucketingPruner - Class in org.apache.hadoop.hive.ql.optimizer.listbucketingpruner
The transformation step that does list bucketing pruning.
ListBucketingPruner() - Constructor for class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPruner
 
ListBucketingPruner.DynamicMultiDimensionalCollection - Class in org.apache.hadoop.hive.ql.optimizer.listbucketingpruner
Note: this class is not designed to be used in general but for list bucketing pruner only.
ListBucketingPruner.DynamicMultiDimensionalCollection() - Constructor for class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPruner.DynamicMultiDimensionalCollection
 
ListBucketingPrunerUtils - Class in org.apache.hadoop.hive.ql.optimizer.listbucketingpruner
Utility for list bucketing prune.
ListBucketingPrunerUtils() - Constructor for class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPrunerUtils
 
listIterator() - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
listIterator(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
listRoles(String, PrincipalType) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
ListSinkDesc - Class in org.apache.hadoop.hive.ql.plan
description for ListSinkOperator, just for explain result.
ListSinkDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ListSinkDesc
 
ListSinkDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.ListSinkDesc
 
ListSinkOperator - Class in org.apache.hadoop.hive.ql.exec
For fetch task with operator tree, row read from FetchOperator is processed via operator tree and finally arrives to this operator.
ListSinkOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.ListSinkOperator
 
listStatusIfExists(Path, FileSystem) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
returns null if path is not exist
load(MapJoinTableContainer[], MapJoinTableContainerSerDe[]) - Method in interface org.apache.hadoop.hive.ql.exec.HashTableLoader
 
load(MapJoinTableContainer[], MapJoinTableContainerSerDe[]) - Method in class org.apache.hadoop.hive.ql.exec.mr.HashTableLoader
 
load(ObjectInputStream) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainerSerDe
 
load(MapJoinTableContainer[], MapJoinTableContainerSerDe[]) - Method in class org.apache.hadoop.hive.ql.exec.tez.HashTableLoader
 
load(byte[][]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CuckooSetBytes
Insert all values in the input array into the set.
load(double[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CuckooSetDouble
Insert all values in the input array into the set.
load(long[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CuckooSetLong
Insert all values in the input array into the set.
load(InputStream) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFInFile
Load the file from an InputStream.
LOAD_HASHTABLE - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
LoadDesc - Class in org.apache.hadoop.hive.ql.plan
LoadDesc.
LoadDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LoadDesc
 
LoadDesc(Path) - Constructor for class org.apache.hadoop.hive.ql.plan.LoadDesc
 
loadDynamicPartitions(Path, String, Map<String, String>, boolean, int, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Given a source directory name of the load path, load all dynamically generated partitions into the specified table and return a list of strings that represent the dynamic partition paths.
LoadFileDesc - Class in org.apache.hadoop.hive.ql.plan
LoadFileDesc.
LoadFileDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
LoadFileDesc(CreateTableDesc, Path, Path, boolean, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
LoadFileDesc(Path, Path, boolean, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
LoadMultiFilesDesc - Class in org.apache.hadoop.hive.ql.plan
LoadMultiFilesDesc.
LoadMultiFilesDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
LoadMultiFilesDesc(List<Path>, List<Path>, boolean, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
loadPartition(Path, String, Map<String, String>, boolean, boolean, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Load a directory into a Hive Table Partition - Alters existing content of the partition with the contents of loadPath.
LoadSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
LoadSemanticAnalyzer.
LoadSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.LoadSemanticAnalyzer
 
loadTable(Path, String, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Load a directory into a Hive Table.
LoadTableDesc - Class in org.apache.hadoop.hive.ql.plan
LoadTableDesc.
LoadTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
LoadTableDesc(Path, TableDesc, Map<String, String>, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
LoadTableDesc(Path, TableDesc, Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
LoadTableDesc(Path, TableDesc, DynamicPartitionCtx) - Constructor for class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
localizeAdditionalFiles(String[]) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
localizeResource(Path, Path, Configuration) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
localizeTempFiles(String, Configuration, String[]) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
Localizes files, archives and jars from a provided array of names.
localizeTempFilesFromConf(String, Configuration) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
Localizes files, archives and jars the user has instructed us to provide on the cluster as resources for execution.
localJobDebugger(int, String) - Method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
LocalMapJoinProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.physical
Node processor factory for map join resolver.
LocalMapJoinProcFactory.LocalMapJoinProcessor - Class in org.apache.hadoop.hive.ql.optimizer.physical
LocalMapJoinProcessor.
LocalMapJoinProcFactory.LocalMapJoinProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory.LocalMapJoinProcessor
 
LocalMapJoinProcFactory.MapJoinFollowedByGroupByProcessor - Class in org.apache.hadoop.hive.ql.optimizer.physical
MapJoinFollowByProcessor.
LocalMapJoinProcFactory.MapJoinFollowedByGroupByProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory.MapJoinFollowedByGroupByProcessor
 
lock(HiveLockObject, HiveLockMode, boolean) - Method in class org.apache.hadoop.hive.ql.lockmgr.DbLockManager
 
lock(List<HiveLockObj>, boolean) - Method in class org.apache.hadoop.hive.ql.lockmgr.DbLockManager
 
lock(HiveLockObject, HiveLockMode, boolean) - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
lock(List<HiveLockObj>, boolean) - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
lock(HiveLockObject, HiveLockMode, int, int) - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
lock(List<HiveLockObj>, int, int) - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
lock(HiveLockObject, HiveLockMode, boolean) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
lock(List<HiveLockObj>, boolean) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
lock(List<HiveLockObj>, boolean) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
lock(HiveLockObject, HiveLockMode, boolean) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
LOCK - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
LockDatabaseDesc - Class in org.apache.hadoop.hive.ql.plan
LockDatabaseDesc.
LockDatabaseDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LockDatabaseDesc
 
LockDatabaseDesc(String, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.LockDatabaseDesc
 
LockException - Exception in org.apache.hadoop.hive.ql.lockmgr
Exception from lock manager.
LockException() - Constructor for exception org.apache.hadoop.hive.ql.lockmgr.LockException
 
LockException(String) - Constructor for exception org.apache.hadoop.hive.ql.lockmgr.LockException
 
LockException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.lockmgr.LockException
 
LockException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.ql.lockmgr.LockException
 
LockTableDesc - Class in org.apache.hadoop.hive.ql.plan
LockTableDesc.
LockTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
LockTableDesc(String, String, Map<String, String>, String) - Constructor for class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.TopNHash
 
LOG - Static variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputFormat
 
LOG - Static variable in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat
 
LOG - Static variable in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
LOG - Static variable in class org.apache.hadoop.hive.ql.io.parquet.read.ParquetRecordReaderWrapper
 
LOG - Static variable in class org.apache.hadoop.hive.ql.io.parquet.write.ParquetRecordWriterWrapper
 
LOG - Static variable in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileMergeMapper
 
LOG - Static variable in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanMapper
 
LOG - Static variable in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateMapper
 
LOG - Static variable in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
LOG - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveMetaStoreChecker
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
 
LOG - Static variable in class org.apache.hadoop.hive.ql.parse.MetaDataExportListener
 
LOG - Static variable in class org.apache.hadoop.hive.ql.processors.AddResourceProcessor
 
LOG - Static variable in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
LOG - Static variable in class org.apache.hadoop.hive.ql.processors.DeleteResourceProcessor
 
LOG - Static variable in class org.apache.hadoop.hive.ql.processors.DfsProcessor
 
LOG - Static variable in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationPreEventListener
 
LOG - Static variable in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
LOG - Static variable in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLAuthorizationUtils
 
LOG - Static variable in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
LOG - Static variable in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAuthorizationValidator
 
log2(double) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
logPlanProgress(SessionState) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
logPlanProgress(SessionState) - Method in interface org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHook
 
logPlanProgress(QueryPlan) - Method in interface org.apache.hadoop.hive.ql.history.HiveHistory
Logs the current plan state
logPlanProgress(QueryPlan) - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
 
logPlanProgress(SessionState) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.BlockMergeTask
 
logPlanProgress(SessionState) - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanTask
 
logPlanProgress(SessionState) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateTask
 
logStats() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
LongColDivideLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This operation is handled as a special case because Hive long/long division returns double.
LongColDivideLongColumn(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongColumn
 
LongColDivideLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongColumn
 
LongColDivideLongScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This operation is handled as a special case because Hive long/long division returns double.
LongColDivideLongScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongScalar
 
LongColDivideLongScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongScalar
 
LongColumnInList - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Output a boolean value indicating if a column is IN a list of constants.
LongColumnInList(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColumnInList
 
LongColumnInList() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColumnInList
 
LongColumnVector - Class in org.apache.hadoop.hive.ql.exec.vector
This class represents a nullable int column vector.
LongColumnVector() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.LongColumnVector
Use this constructor by default.
LongColumnVector(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.LongColumnVector
Don't use this except for testing purposes.
LongNumDistinctValueEstimator - Class in org.apache.hadoop.hive.ql.udf.generic
 
LongNumDistinctValueEstimator(int) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.LongNumDistinctValueEstimator
 
LongNumDistinctValueEstimator(String, int) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.LongNumDistinctValueEstimator
 
LongScalarDivideLongColumn - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This operation is handled as a special case because Hive long/long division returns double.
LongScalarDivideLongColumn(long, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarDivideLongColumn
 
LongScalarDivideLongColumn() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarDivideLongColumn
 
LongToStringUnaryUDF - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This is a superclass for unary long functions returning strings that operate directly on the input and set the output.
LongToStringUnaryUDF(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.LongToStringUnaryUDF
 
LongToStringUnaryUDF() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.LongToStringUnaryUDF
 
longToTimestamp(long) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
lookup(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CuckooSetBytes
Return true if and only if the value in byte array b beginning at start and ending at start+len is present in the set.
lookup(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CuckooSetDouble
Return true if and only if the value x is present in the set.
lookup(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CuckooSetLong
Return true if and only if the value x is present in the set.

M

MacroSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
MacroSemanticAnalyzer.
MacroSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.MacroSemanticAnalyzer
 
MAGIC - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcFile
 
main(String[]) - Static method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
main(String[]) - Static method in class org.apache.hadoop.hive.ql.io.orc.FileDump
 
main(String[]) - Static method in class org.apache.hadoop.hive.ql.io.rcfile.merge.BlockMergeTask
 
main(String[]) - Static method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanTask
 
main(String[]) - Static method in class org.apache.hadoop.hive.ql.tools.LineageInfo
 
makeChild(Operator<? extends OperatorDesc>, Operator<? extends OperatorDesc>...) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
Returns an operator given the conf and a list of children operators.
makeChild(Task<?>, Task<? extends Serializable>...) - Static method in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
makeList(Object...) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
makeMap(Object...) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
makePartSpec(List<FieldSchema>, List<String>) - Static method in class org.apache.hadoop.hive.ql.parse.EximUtil
Return the partition specification from the specified keys and values
makeProperties(String...) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
makeQueryId() - Static method in class org.apache.hadoop.hive.ql.QueryPlan
 
makeSessionId() - Static method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
makeTransient(Class<?>, String...) - Static method in class org.apache.hadoop.hive.ql.exec.PTFUtils
 
map(Object, Object, OutputCollector, Reporter) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapper
 
MAP - Static variable in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe
 
map(Object, RCFileValueBufferWrapper, OutputCollector<Object, Object>, Reporter) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileMergeMapper
 
map(Object, RCFileValueBufferWrapper, OutputCollector<Object, Object>, Reporter) - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanMapper
 
map(Object, RCFileValueBufferWrapper, OutputCollector<Object, Object>, Reporter) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateMapper
 
MAP_KEY - Static variable in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe
 
MAP_PLAN_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
MAP_VALUE - Static variable in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe
 
mapAggregationBufferSet(VectorAggregationBufferRow, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferBatch
assigns the given aggregation buffer set to a given batch row (by row number).
MapAggrMemErrorHeuristic - Class in org.apache.hadoop.hive.ql.exec.errors
Detects out-of-memory errors when hash tables in map-based aggregation group by queries take up too much memory.
MapAggrMemErrorHeuristic() - Constructor for class org.apache.hadoop.hive.ql.exec.errors.MapAggrMemErrorHeuristic
 
MapBuilder - Class in org.apache.hadoop.hive.ql.metadata.formatting
Helper class to build Maps consumed by the JSON formatter.
mapDirToFop(Path, FileSinkOperator) - Method in class org.apache.hadoop.hive.ql.session.LineageState
Adds a mapping from the load work to the file sink operator.
mapDone() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
mapDone() - Method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
mapDone() - Method in class org.apache.hadoop.hive.ql.exec.mr.MapRedTask
 
mapInputToDP(List<ColumnInfo>) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
MAPJOIN_ONLY_NOBACKUP - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
mapJoinConversionPos(JoinOperator, OptimizeTezProcContext, int) - Method in class org.apache.hadoop.hive.ql.optimizer.ConvertJoinMapJoin
 
MapJoinDesc - Class in org.apache.hadoop.hive.ql.plan
Map Join operator Descriptor implementation.
MapJoinDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
MapJoinDesc(MapJoinDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
MapJoinDesc(Map<Byte, List<ExprNodeDesc>>, TableDesc, Map<Byte, List<ExprNodeDesc>>, List<TableDesc>, List<TableDesc>, List<String>, int, JoinCondDesc[], Map<Byte, List<ExprNodeDesc>>, boolean, String) - Constructor for class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
MapJoinEagerRowContainer - Class in org.apache.hadoop.hive.ql.exec.persistence
 
MapJoinEagerRowContainer() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
MapJoinFactory - Class in org.apache.hadoop.hive.ql.optimizer
Operator factory for MapJoin processing.
MapJoinKey - Class in org.apache.hadoop.hive.ql.exec.persistence
The base class for MapJoinKey; also acts as a factory for creating and reading the keys, choosing whether size-optimized byte-array based MJKBytes can be used.
MapJoinKey() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKey
 
MapJoinKeyBytes - Class in org.apache.hadoop.hive.ql.exec.persistence
Size-optimized implementation of MapJoinKeyBase.
MapJoinKeyBytes() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyBytes
 
MapJoinKeyObject - Class in org.apache.hadoop.hive.ql.exec.persistence
 
MapJoinKeyObject(Object[]) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyObject
 
MapJoinKeyObject() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyObject
 
MapJoinMemoryExhaustionException - Exception in org.apache.hadoop.hive.ql.exec.mapjoin
 
MapJoinMemoryExhaustionException(String) - Constructor for exception org.apache.hadoop.hive.ql.exec.mapjoin.MapJoinMemoryExhaustionException
 
MapJoinMemoryExhaustionHandler - Class in org.apache.hadoop.hive.ql.exec.mapjoin
Handles the logic around deciding when to throw an MapJoinMemoryExhaustionException for HashTableSinkOperator.
MapJoinMemoryExhaustionHandler(SessionState.LogHelper, double) - Constructor for class org.apache.hadoop.hive.ql.exec.mapjoin.MapJoinMemoryExhaustionHandler
Constructor expects a LogHelper object in addition to the max percent of heap memory which can be consumed before a MapJoinMemoryExhaustionException is thrown.
MapJoinObjectSerDeContext - Class in org.apache.hadoop.hive.ql.exec.persistence
 
MapJoinObjectSerDeContext(SerDe, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectSerDeContext
 
MapJoinOperator - Class in org.apache.hadoop.hive.ql.exec
Map side Join operator implementation.
MapJoinOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
MapJoinOperator(AbstractMapJoinOperator<? extends MapJoinDesc>) - Constructor for class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
mapJoinParentMap - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
MapJoinProcessor - Class in org.apache.hadoop.hive.ql.optimizer
Implementation of one of the rule-based map join optimization.
MapJoinProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
empty constructor.
MapJoinProcessor.CurrentMapJoin - Class in org.apache.hadoop.hive.ql.optimizer
CurrentMapJoin.
MapJoinProcessor.CurrentMapJoin() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.CurrentMapJoin
 
MapJoinProcessor.Default - Class in org.apache.hadoop.hive.ql.optimizer
Default.
MapJoinProcessor.Default() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.Default
 
MapJoinProcessor.MapJoinDefault - Class in org.apache.hadoop.hive.ql.optimizer
MapJoinDefault.
MapJoinProcessor.MapJoinDefault() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinDefault
 
MapJoinProcessor.MapJoinFS - Class in org.apache.hadoop.hive.ql.optimizer
MapJoinFS.
MapJoinProcessor.MapJoinFS() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinFS
 
MapJoinProcessor.MapJoinWalkerCtx - Class in org.apache.hadoop.hive.ql.optimizer
MapJoinWalkerCtx.
MapJoinProcessor.MapJoinWalkerCtx(List<AbstractMapJoinOperator<? extends MapJoinDesc>>, ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
MapJoinResolver - Class in org.apache.hadoop.hive.ql.optimizer.physical
An implementation of PhysicalPlanResolver.
MapJoinResolver() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver
 
MapJoinResolver.LocalMapJoinProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.physical
A container of current task and parse context.
MapJoinResolver.LocalMapJoinProcCtx(Task<? extends Serializable>, ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
MapJoinRowContainer - Interface in org.apache.hadoop.hive.ql.exec.persistence
 
MapJoinTableContainer - Interface in org.apache.hadoop.hive.ql.exec.persistence
 
MapJoinTableContainerSerDe - Class in org.apache.hadoop.hive.ql.exec.persistence
 
MapJoinTableContainerSerDe(MapJoinObjectSerDeContext, MapJoinObjectSerDeContext) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainerSerDe
 
mapJoinWorkMap - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
MapOperator - Class in org.apache.hadoop.hive.ql.exec
Map operator.
MapOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.MapOperator
 
MapOperator.Counter - Enum in org.apache.hadoop.hive.ql.exec
Counter.
MapRecordProcessor - Class in org.apache.hadoop.hive.ql.exec.tez
Process input from tez LogicalInput and write output - for a map plan Just pump the records through the query plan.
MapRecordProcessor() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor
 
MAPRED_MAPPER_CLASS - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
MAPRED_REDUCER_CLASS - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
MAPRED_TASK_ID - Static variable in class org.apache.hadoop.hive.ql.io.IOConstants
 
MapredContext - Class in org.apache.hadoop.hive.ql.exec
Runtime context of MapredTask providing additional information to GenericUDF
MapredLocalTask - Class in org.apache.hadoop.hive.ql.exec.mr
MapredLocalTask represents any local work (i.e.: client side work) that hive needs to execute.
MapredLocalTask() - Constructor for class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
MapredLocalTask(MapredLocalWork, JobConf, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
MapredLocalWork - Class in org.apache.hadoop.hive.ql.plan
MapredLocalWork.
MapredLocalWork() - Constructor for class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
MapredLocalWork(LinkedHashMap<String, Operator<? extends OperatorDesc>>, LinkedHashMap<String, FetchWork>) - Constructor for class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
MapredLocalWork(MapredLocalWork) - Constructor for class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
MapredParquetInputFormat - Class in org.apache.hadoop.hive.ql.io.parquet
A Parquet InputFormat for Hive (with the deprecated package mapred)
MapredParquetInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.parquet.MapredParquetInputFormat
 
MapredParquetOutputFormat - Class in org.apache.hadoop.hive.ql.io.parquet
A Parquet OutputFormat for Hive (with the deprecated package mapred)
MapredParquetOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.parquet.MapredParquetOutputFormat
 
MapredParquetOutputFormat(OutputFormat<Void, ArrayWritable>) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.MapredParquetOutputFormat
 
MapRedStats - Class in org.apache.hadoop.hive.ql
MapRedStats.
MapRedStats(int, int, long, boolean, String) - Constructor for class org.apache.hadoop.hive.ql.MapRedStats
 
MapRedTask - Class in org.apache.hadoop.hive.ql.exec.mr
Extension of ExecDriver: - can optionally spawn a map-reduce task from a separate jvm - will make last minute adjustments to map-reduce job parameters, viz: * estimating number of reducers * estimating whether job should run locally
MapRedTask() - Constructor for class org.apache.hadoop.hive.ql.exec.mr.MapRedTask
 
MapReduceCompiler - Class in org.apache.hadoop.hive.ql.parse
 
MapReduceCompiler() - Constructor for class org.apache.hadoop.hive.ql.parse.MapReduceCompiler
 
MapredWork - Class in org.apache.hadoop.hive.ql.plan
MapredWork.
MapredWork() - Constructor for class org.apache.hadoop.hive.ql.plan.MapredWork
 
mapStarted() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
mapStarted() - Method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
mapStarted() - Method in class org.apache.hadoop.hive.ql.exec.mr.MapRedTask
 
MapTezProcessor - Class in org.apache.hadoop.hive.ql.exec.tez
Subclass that is used to indicate if this is a map or reduce process
MapTezProcessor() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.MapTezProcessor
 
MapWork - Class in org.apache.hadoop.hive.ql.plan
MapWork represents all the information used to run a map task on the cluster.
MapWork() - Constructor for class org.apache.hadoop.hive.ql.plan.MapWork
 
MapWork(String) - Constructor for class org.apache.hadoop.hive.ql.plan.MapWork
 
mark(int) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
markSupported() - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
matchCost(TypeInfo, TypeInfo, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns -1 if passed does not match accepted.
matches(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.rules.HivePushJoinThroughJoinRule
 
matches(RelOptRuleCall) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.rules.HiveSwapJoinRule
 
matchFilesOrDir(FileSystem, Path) - Static method in class org.apache.hadoop.hive.ql.parse.LoadSemanticAnalyzer
 
MathExpr - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Math expression evaluation helper functions.
MathExpr() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
MathFuncDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Implement vectorized math function that takes a double (and optionally additional constant argument(s)) and returns long.
MathFuncDoubleToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncDoubleToDouble
 
MathFuncDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncDoubleToDouble
 
MathFuncLongToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Implement vectorized math function that takes a double (and optionally additional constant argument(s)) and returns long.
MathFuncLongToDouble(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToDouble
 
MathFuncLongToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToDouble
 
MathFuncLongToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Implement vectorized math function that takes a long (and optionally additional constant argument(s)) and returns long.
MathFuncLongToLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToLong
 
MathFuncLongToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToLong
 
max - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator.DecimalStatsAgg
 
max - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.DoubleStatsAgg
 
max - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.LongStatsAgg
 
maximumTransactionId(long) - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
The maximum transaction id that is included in this file.
maxLength(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.ReaderOptions
 
maxLength - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator.BinaryStatsAgg
 
maxLength - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg
 
memoryAlign() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
memoryMXBean - Static variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
memoryMXBean - Variable in class org.apache.hadoop.hive.ql.exec.mapjoin.MapJoinMemoryExhaustionHandler
 
memoryMXBean - Static variable in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
memoryMXBean - Static variable in class org.apache.hadoop.hive.ql.exec.mr.ExecMapper
 
memoryMXBean - Static variable in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
memoryMXBean - Static variable in class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
merge(ExprWalkerInfo) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Merges the specified pushdown predicates with the current class.
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Merge with partial aggregation result.
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEWAHBitmap.GenericUDAFEWAHBitmapEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFFirstValue.GenericUDAFFirstValueEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLastValue.GenericUDAFLastValueEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMkCollectionEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFNTile.GenericUDAFNTileEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank.GenericUDAFRankEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRowNumber.GenericUDAFRowNumberEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumDouble
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumHiveDecimal
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumLong
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance.GenericUDAFVarianceEvaluator
 
merge(List<Text>) - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Takes a serialized n-gram estimator object created by the serialize() method and merges it with the current n-gram object.
merge(List<DoubleWritable>) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Takes a serialized histogram created by the serialize() method and merges it with the current histogram object.
merge(UDAFPercentile.State) - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongArrayEvaluator
 
merge(UDAFPercentile.State) - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongEvaluator
 
merge() - Method in class org.apache.hadoop.hive.ql.udf.UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator
 
mergeAliasedInput(String, String, PartitionDesc) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
mergeDependency(Operator<? extends OperatorDesc>, ColumnInfo, LineageInfo.Dependency) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx.Index
Merges the new dependencies in dep to the existing dependencies of (op, ci).
mergeEstimators(NumDistinctValueEstimator) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
mergePredicates(ExprNodeDesc, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
bind two predicates by AND op
mergePredicates(List<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
bind n predicates by AND op
mergeRHSSemijoin(QBJoinTree) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
Merge the rhs tables from another join tree.
mergeUniqElems(List<String>, List<String>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
MergeWork - Class in org.apache.hadoop.hive.ql.io.rcfile.merge
 
MergeWork() - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
MergeWork(List<Path>, Path) - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
MergeWork(List<Path>, Path, boolean, DynamicPartitionCtx) - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
mergingInto(MapWork) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
Metadata - Class in org.apache.hadoop.hive.ql.io.orc
 
METADATA_FORMAT_FORWARD_COMPATIBLE_VERSION - Static variable in class org.apache.hadoop.hive.ql.parse.EximUtil
 
METADATA_FORMAT_VERSION - Static variable in class org.apache.hadoop.hive.ql.parse.EximUtil
 
METADATA_NAME - Static variable in class org.apache.hadoop.hive.ql.parse.ImportSemanticAnalyzer
 
MetaDataExportListener - Class in org.apache.hadoop.hive.ql.parse
This class listens for drop events and, if set, exports the table's metadata as JSON to the trash of the user performing the drop
MetaDataExportListener(Configuration) - Constructor for class org.apache.hadoop.hive.ql.parse.MetaDataExportListener
Configure the export listener
MetaDataFormatter - Interface in org.apache.hadoop.hive.ql.metadata.formatting
Interface to format table and index information.
MetaDataFormatUtils - Class in org.apache.hadoop.hive.ql.metadata.formatting
This class provides methods to format table and index information.
MetadataOnlyOptimizer - Class in org.apache.hadoop.hive.ql.optimizer.physical
MetadataOnlyOptimizer determines to which TableScanOperators "metadata only" optimization can be applied.
MetadataOnlyOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.MetadataOnlyOptimizer
 
MetaDataPrettyFormatUtils - Class in org.apache.hadoop.hive.ql.metadata.formatting
This class provides methods to format the output of DESCRIBE PRETTY in a human-readable way.
min - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator.DecimalStatsAgg
 
min - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.DoubleStatsAgg
 
min - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.LongStatsAgg
 
minimumTransactionId(long) - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
The minimum transaction id that is included in this file.
minus(RelOptCost) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCost
 
moduloChecked(int, Decimal128, Decimal128, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
monitorExecution(DAGClient, HiveTxnManager, HiveConf) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezJobMonitor
monitorExecution handles status printing, failures during execution and final status retrieval.
MoveTask - Class in org.apache.hadoop.hive.ql.exec
MoveTask implementation.
MoveTask() - Constructor for class org.apache.hadoop.hive.ql.exec.MoveTask
 
moveTask - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
MoveWork - Class in org.apache.hadoop.hive.ql.plan
MoveWork.
MoveWork() - Constructor for class org.apache.hadoop.hive.ql.plan.MoveWork
 
MoveWork(HashSet<ReadEntity>, HashSet<WriteEntity>) - Constructor for class org.apache.hadoop.hive.ql.plan.MoveWork
 
MoveWork(HashSet<ReadEntity>, HashSet<WriteEntity>, LoadTableDesc, LoadFileDesc, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.MoveWork
 
MsckDesc - Class in org.apache.hadoop.hive.ql.plan
MsckDesc.
MsckDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.MsckDesc
For serialization use only.
MsckDesc(String, List<? extends Map<String, String>>, Path, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.MsckDesc
Description of a msck command.
multiplyBy(double) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCost
 
multiplyChecked(int, Decimal128, Decimal128, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
MuxDesc - Class in org.apache.hadoop.hive.ql.plan
Mux operator descriptor implementation..
MuxDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.MuxDesc
 
MuxDesc(List<Operator<? extends OperatorDesc>>) - Constructor for class org.apache.hadoop.hive.ql.plan.MuxDesc
 
MuxOperator - Class in org.apache.hadoop.hive.ql.exec
MuxOperator is used in the Reduce side of MapReduce jobs optimized by Correlation Optimizer.
MuxOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.MuxOperator
 
mvFileToFinalPath(Path, Configuration, boolean, Log, DynamicPartitionCtx, FileSinkDesc, Reporter) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 

N

NAMED - Static variable in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
NaNToNull(DoubleColumnVector, int[], boolean, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
NaNToNull(DoubleColumnVector, int[], boolean, int, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
needsTagging(ReduceWork) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
negate(int, Decimal128, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
newBuilder() - Method in class org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Factory
 
newFactory(Configuration) - Static method in class org.apache.hadoop.hive.ql.stats.StatsFactory
 
newFactory(String, Configuration) - Static method in class org.apache.hadoop.hive.ql.stats.StatsFactory
Sets the paths of the implementation classes of publishing and aggregation (IStatsPublisher and IStatsAggregator interfaces).
newInstance(GenericUDF, String, List<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
Create a ExprNodeGenericFuncDesc based on the genericUDFClass and the children parameters.
newInstance(GenericUDF, List<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
newLineCode - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
newTable(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
next(Writable) - Method in class org.apache.hadoop.hive.ql.exec.BinaryRecordReader
 
next() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer.RowIterator
 
next() - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
next() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
next() - Method in class org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer
 
next() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
next() - Method in class org.apache.hadoop.hive.ql.exec.PTFUtils.ReverseIterator
 
next(Writable) - Method in interface org.apache.hadoop.hive.ql.exec.RecordReader
Returns the number of bytes that we consumed.
next(Writable) - Method in class org.apache.hadoop.hive.ql.exec.TextRecordReader
 
next() - Method in class org.apache.hadoop.hive.ql.exec.tez.tools.InputMerger
 
next(NullWritable, AvroGenericRecordWritable) - Method in class org.apache.hadoop.hive.ql.io.avro.AvroGenericRecordReader
 
next(Void, FlatFileInputFormat.RowContainer<R>) - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
Returns the next row # and value.
next(K, V) - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
next(NullWritable, NullWritable) - Method in class org.apache.hadoop.hive.ql.io.NullRowsInputFormat.NullRowsRecordReader
 
next(NullWritable, NullWritable) - Method in class org.apache.hadoop.hive.ql.io.OneNullRowInputFormat.OneNullRowRecordReader
 
next(RecordIdentifier, OrcStruct) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRawRecordMerger
 
next(Object) - Method in interface org.apache.hadoop.hive.ql.io.orc.RecordReader
Read the next row.
next(Void, ArrayWritable) - Method in class org.apache.hadoop.hive.ql.io.parquet.read.ParquetRecordReaderWrapper
 
next(RCFileKeyBufferWrapper, RCFileValueBufferWrapper) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeRecordReader
 
next(LongWritable) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Returns how many rows we fetched with next().
next(LongWritable, BytesRefArrayWritable) - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
next(NullWritable, VectorizedRowBatch) - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
next(HiveConf, SemanticAnalyzer, UnparseTranslator, RowResolver) - Method in class org.apache.hadoop.hive.ql.parse.WindowingComponentizer
 
nextBatch(VectorizedRowBatch) - Method in interface org.apache.hadoop.hive.ql.io.orc.RecordReader
Read the next row batch.
nextBlock() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
 
nextBlock() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
nextBlock() - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
nextColumnsBatch() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Deprecated. 
NGramEstimator - Class in org.apache.hadoop.hive.ql.udf.generic
A generic, re-usable n-gram estimation class that supports partial aggregations.
NGramEstimator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Creates a new n-gram estimator object.
NO_TAG - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
Node - Interface in org.apache.hadoop.hive.ql.lib
This interface defines the functions needed by the walkers and dispatchers.
NodeProcessor - Interface in org.apache.hadoop.hive.ql.lib
Base class for processing operators which is no-op.
NodeProcessorCtx - Interface in org.apache.hadoop.hive.ql.lib
Operator Processor Context.
NodeUtils - Class in org.apache.hadoop.hive.ql.exec
Simple node iterating utils
NodeUtils() - Constructor for class org.apache.hadoop.hive.ql.exec.NodeUtils
 
NodeUtils.Function<T> - Interface in org.apache.hadoop.hive.ql.exec
 
NoMatchingMethodException - Exception in org.apache.hadoop.hive.ql.exec
Exception thrown by the UDF and UDAF method resolvers in case no matching method is found.
NoMatchingMethodException(Class<?>, List<TypeInfo>, List<Method>) - Constructor for exception org.apache.hadoop.hive.ql.exec.NoMatchingMethodException
Constructor.
NonBlockingOpDeDupProc - Class in org.apache.hadoop.hive.ql.optimizer
merges SEL-SEL or FIL-FIL into single operator
NonBlockingOpDeDupProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.NonBlockingOpDeDupProc
 
NonSyncDataInputBuffer - Class in org.apache.hadoop.hive.ql.io
A thread-not-safe version of Hadoop's DataInputBuffer, which removes all synchronized modifiers.
NonSyncDataInputBuffer() - Constructor for class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Constructs a new empty buffer.
NonSyncDataOutputBuffer - Class in org.apache.hadoop.hive.ql.io
A thread-not-safe version of Hadoop's DataOutputBuffer, which removes all synchronized modifiers.
NonSyncDataOutputBuffer() - Constructor for class org.apache.hadoop.hive.ql.io.NonSyncDataOutputBuffer
Constructs a new empty buffer.
noNulls - Variable in class org.apache.hadoop.hive.ql.exec.vector.ColumnVector
 
Noop - Class in org.apache.hadoop.hive.ql.udf.ptf
 
Noop() - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.Noop
 
Noop.NoopResolver - Class in org.apache.hadoop.hive.ql.udf.ptf
 
Noop.NoopResolver() - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.Noop.NoopResolver
 
NOOP_MAP_TABLE_FUNCTION - Static variable in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
NOOP_TABLE_FUNCTION - Static variable in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
NoopWithMap - Class in org.apache.hadoop.hive.ql.udf.ptf
 
NoopWithMap() - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMap
 
NoopWithMap.NoopWithMapResolver - Class in org.apache.hadoop.hive.ql.udf.ptf
 
NoopWithMap.NoopWithMapResolver() - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMap.NoopWithMapResolver
 
noOuterJoin - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
not() - Method in enum org.apache.hadoop.hive.ql.io.sarg.SearchArgument.TruthValue
 
notBoolOperand(Boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPrunerUtils
Not a Boolean operand in the context of pruning match Operand | Not T | F F | T unknown | unknown
NotCol - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Evaluates the boolean complement of the input.
NotCol(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.NotCol
 
NotCol() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.NotCol
 
now() - Static method in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
now() - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
NSTR - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
NULL_VALUE - Static variable in class org.apache.hadoop.hive.ql.exec.vector.DoubleColumnVector
 
NULL_VALUE - Static variable in class org.apache.hadoop.hive.ql.exec.vector.LongColumnVector
 
nullColumn(int) - Method in class org.apache.hadoop.hive.ql.io.RCFile.KeyBuffer
 
nullColumn(int) - Method in class org.apache.hadoop.hive.ql.io.RCFile.ValueBuffer
 
NullRowsInputFormat - Class in org.apache.hadoop.hive.ql.io
NullRowsInputFormat outputs null rows, maximum 100.
NullRowsInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.NullRowsInputFormat
 
NullRowsInputFormat.DummyInputSplit - Class in org.apache.hadoop.hive.ql.io
 
NullRowsInputFormat.DummyInputSplit() - Constructor for class org.apache.hadoop.hive.ql.io.NullRowsInputFormat.DummyInputSplit
 
NullRowsInputFormat.NullRowsRecordReader - Class in org.apache.hadoop.hive.ql.io
 
NullRowsInputFormat.NullRowsRecordReader() - Constructor for class org.apache.hadoop.hive.ql.io.NullRowsInputFormat.NullRowsRecordReader
 
nullSafeEquals(String, Object) - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Builder
Add a null safe equals leaf to the current item on the stack.
nullStringOutput - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
nullStringStorage - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
NullUtil - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Utility functions to handle null propagation.
NullUtil() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.NullUtil
 
numBitVectors - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator.DecimalStatsAgg
 
numBitVectors - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.DoubleStatsAgg
 
numBitVectors - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.LongStatsAgg
 
numBitVectors - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg
 
numCols - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
NumDistinctValueEstimator - Class in org.apache.hadoop.hive.ql.udf.generic
 
NumDistinctValueEstimator(int) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
NumDistinctValueEstimator(String, int) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
numDV - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator.DecimalStatsAgg
 
numDV - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.DoubleStatsAgg
 
numDV - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.LongStatsAgg
 
numDV - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg
 
numDynParts - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
NumericHistogram - Class in org.apache.hadoop.hive.ql.udf.generic
A generic, re-usable histogram class that supports partial aggregations.
NumericHistogram() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Creates a new histogram object.
NumericOpMethodResolver - Class in org.apache.hadoop.hive.ql.exec
The class implements the method resolution for operators like (+, -, *, %).
NumericOpMethodResolver(Class<? extends UDF>) - Constructor for class org.apache.hadoop.hive.ql.exec.NumericOpMethodResolver
Constuctor.
NumericUDAF - Class in org.apache.hadoop.hive.ql.exec
Base class of numeric UDAFs like sum and avg which need a NumericUDAFEvaluatorResolver.
NumericUDAF() - Constructor for class org.apache.hadoop.hive.ql.exec.NumericUDAF
Constructor.
NumericUDAFEvaluatorResolver - Class in org.apache.hadoop.hive.ql.exec
Resolver for Numeric UDAFs like sum and avg.
NumericUDAFEvaluatorResolver(Class<? extends UDAF>) - Constructor for class org.apache.hadoop.hive.ql.exec.NumericUDAFEvaluatorResolver
Constructor.

O

object() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
ObjectCache - Class in org.apache.hadoop.hive.ql.exec.mr
ObjectCache.
ObjectCache() - Constructor for class org.apache.hadoop.hive.ql.exec.mr.ObjectCache
 
ObjectCache - Interface in org.apache.hadoop.hive.ql.exec
ObjectCache.
ObjectCache - Class in org.apache.hadoop.hive.ql.exec.tez
ObjectCache.
ObjectCache() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.ObjectCache
 
ObjectCacheFactory - Class in org.apache.hadoop.hive.ql.exec
ObjectCacheFactory returns the appropriate cache depending on settings in the hive conf.
OneNullRowInputFormat - Class in org.apache.hadoop.hive.ql.io
OneNullRowInputFormat outputs one null row.
OneNullRowInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.OneNullRowInputFormat
 
OneNullRowInputFormat.OneNullRowRecordReader - Class in org.apache.hadoop.hive.ql.io
 
OneNullRowInputFormat.OneNullRowRecordReader() - Constructor for class org.apache.hadoop.hive.ql.io.OneNullRowInputFormat.OneNullRowRecordReader
 
onEvent(PreEventContext) - Method in class org.apache.hadoop.hive.ql.parse.MetaDataExportListener
Listen for an event; if it is a DROP_TABLE event, call export_meta_data
onEvent(PreEventContext) - Method in class org.apache.hadoop.hive.ql.security.authorization.AuthorizationPreEventListener
 
onlyContainsPartnCols(Table, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
Find out whether the condition only contains partitioned columns.
onRootVertexInitialized(String, InputDescriptor, List<Event>) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionVertex
 
onSourceTaskCompleted(String, Integer) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionVertex
 
onVertexManagerEventReceived(VertexManagerEvent) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionVertex
 
onVertexStarted(Map<String, List<Integer>>) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionVertex
 
opAllowedAfterMapJoin() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
opAllowedAfterMapJoin() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
opAllowedAfterMapJoin() - Method in class org.apache.hadoop.hive.ql.exec.UnionOperator
 
opAllowedBeforeMapJoin() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
opAllowedBeforeMapJoin() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
opAllowedBeforeMapJoin() - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
opAllowedBeforeMapJoin() - Method in class org.apache.hadoop.hive.ql.exec.UnionOperator
Union operators are not allowed either before or after a explicit mapjoin hint.
opAllowedBeforeSortMergeJoin() - Method in class org.apache.hadoop.hive.ql.exec.JoinOperator
 
opAllowedBeforeSortMergeJoin() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
opAllowedBeforeSortMergeJoin() - Method in class org.apache.hadoop.hive.ql.exec.UnionOperator
 
opAllowedConvertMapJoin() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
opAllowedConvertMapJoin() - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
opClass - Variable in class org.apache.hadoop.hive.ql.exec.OperatorFactory.OpTuple
 
open(HiveConf) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
open(HiveConf, String[]) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
Creates a tez session.
openTxn(String) - Method in class org.apache.hadoop.hive.ql.lockmgr.DbTxnManager
 
openTxn(String) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveTxnManager
Open a new transaction.
Operation2Privilege - Class in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
Mapping of operation to its required input and output privileges
Operation2Privilege() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.Operation2Privilege
 
Operator<T extends OperatorDesc> - Class in org.apache.hadoop.hive.ql.exec
Base operator implementation.
Operator() - Constructor for class org.apache.hadoop.hive.ql.exec.Operator
 
Operator(Reporter) - Constructor for class org.apache.hadoop.hive.ql.exec.Operator
Create an operator with a reporter.
Operator.OperatorFunc - Interface in org.apache.hadoop.hive.ql.exec
OperatorFunc.
Operator.State - Enum in org.apache.hadoop.hive.ql.exec
State.
OperatorDesc - Interface in org.apache.hadoop.hive.ql.plan
 
operatorExists(HashSet<Operator>, boolean, Set<OperatorType>) - Static method in class org.apache.hadoop.hive.ql.optimizer.CostBasedOptimizer
Check if operator tree, in the direction specified forward/backward, contains any operator specified in the targetOPTypes.
OperatorFactory - Class in org.apache.hadoop.hive.ql.exec
OperatorFactory.
OperatorFactory.OpTuple<T extends OperatorDesc> - Class in org.apache.hadoop.hive.ql.exec
OpTuple.
OperatorFactory.OpTuple(Class<T>, Class<? extends Operator<T>>) - Constructor for class org.apache.hadoop.hive.ql.exec.OperatorFactory.OpTuple
 
OperatorUtils - Class in org.apache.hadoop.hive.ql.exec
 
OperatorUtils() - Constructor for class org.apache.hadoop.hive.ql.exec.OperatorUtils
 
OpParseContext - Class in org.apache.hadoop.hive.ql.parse
Implementation of the Operator Parse Context.
OpParseContext() - Constructor for class org.apache.hadoop.hive.ql.parse.OpParseContext
 
OpParseContext(RowResolver) - Constructor for class org.apache.hadoop.hive.ql.parse.OpParseContext
 
OpProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Operator factory for the rule processors for lineage.
OpProcFactory() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
OpProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.ppr
Operator factory for partition pruning processing of operator graph We find all the filter operators that appear just beneath the table scan operators.
OpProcFactory - Class in org.apache.hadoop.hive.ql.ppd
Operator factory for predicate pushdown processing of operator graph Each operator determines the pushdown predicates by walking the expression tree.
OpProcFactory.DefaultLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Default processor.
OpProcFactory.DefaultLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.DefaultLineage
 
OpProcFactory.DefaultPPD - Class in org.apache.hadoop.hive.ql.ppd
Default processor which just merges its children.
OpProcFactory.DefaultPPD() - Constructor for class org.apache.hadoop.hive.ql.ppd.OpProcFactory.DefaultPPD
 
OpProcFactory.FilterPPD - Class in org.apache.hadoop.hive.ql.ppd
Determines the push down predicates in its where expression and then combines it with the push down predicates that are passed from its children.
OpProcFactory.FilterPPD() - Constructor for class org.apache.hadoop.hive.ql.ppd.OpProcFactory.FilterPPD
 
OpProcFactory.FilterPPR - Class in org.apache.hadoop.hive.ql.optimizer.ppr
Determines the partition pruner for the filter.
OpProcFactory.FilterPPR() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.OpProcFactory.FilterPPR
 
OpProcFactory.GroupByLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for GroupBy operator.
OpProcFactory.GroupByLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.GroupByLineage
 
OpProcFactory.JoinerPPD - Class in org.apache.hadoop.hive.ql.ppd
Determines predicates for which alias can be pushed to it's parents.
OpProcFactory.JoinerPPD() - Constructor for class org.apache.hadoop.hive.ql.ppd.OpProcFactory.JoinerPPD
 
OpProcFactory.JoinLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for Join Operator.
OpProcFactory.JoinLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.JoinLineage
 
OpProcFactory.JoinPPD - Class in org.apache.hadoop.hive.ql.ppd
 
OpProcFactory.JoinPPD() - Constructor for class org.apache.hadoop.hive.ql.ppd.OpProcFactory.JoinPPD
 
OpProcFactory.LateralViewForwardPPD - Class in org.apache.hadoop.hive.ql.ppd
 
OpProcFactory.LateralViewForwardPPD() - Constructor for class org.apache.hadoop.hive.ql.ppd.OpProcFactory.LateralViewForwardPPD
 
OpProcFactory.LateralViewJoinLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for Join Operator.
OpProcFactory.LateralViewJoinLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.LateralViewJoinLineage
 
OpProcFactory.ReduceSinkLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
ReduceSink processor.
OpProcFactory.ReduceSinkLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.ReduceSinkLineage
 
OpProcFactory.ScriptPPD - Class in org.apache.hadoop.hive.ql.ppd
Processor for Script Operator Prevents any predicates being pushed.
OpProcFactory.ScriptPPD() - Constructor for class org.apache.hadoop.hive.ql.ppd.OpProcFactory.ScriptPPD
 
OpProcFactory.SelectLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for Select operator.
OpProcFactory.SelectLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.SelectLineage
 
OpProcFactory.TableScanLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for TableScan Operator.
OpProcFactory.TableScanLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.TableScanLineage
 
OpProcFactory.TableScanPPD - Class in org.apache.hadoop.hive.ql.ppd
Combines predicates of its child into a single expression and adds a filter op as new child.
OpProcFactory.TableScanPPD() - Constructor for class org.apache.hadoop.hive.ql.ppd.OpProcFactory.TableScanPPD
 
OpProcFactory.TransformLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for Script and UDTF Operators.
OpProcFactory.TransformLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.TransformLineage
 
OpProcFactory.UDTFPPD - Class in org.apache.hadoop.hive.ql.ppd
 
OpProcFactory.UDTFPPD() - Constructor for class org.apache.hadoop.hive.ql.ppd.OpProcFactory.UDTFPPD
 
OpProcFactory.UnionLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Union processor.
OpProcFactory.UnionLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.UnionLineage
 
optimize(Operator, SemanticAnalyzer, ParseContext, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.optimizer.CostBasedOptimizer
 
optimize() - Method in class org.apache.hadoop.hive.ql.optimizer.Optimizer
Invoke all the transformations one-by-one, and alter the query plan.
optimize() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalOptimizer
invoke all the resolvers one-by-one, and alter the physical plan.
optimize() - Method in class org.apache.hadoop.hive.ql.optimizer.PreCBOOptimizer
Invoke all the transformations one-by-one, and alter the query plan.
Optimizer - Class in org.apache.hadoop.hive.ql.optimizer
Implementation of the optimizer.
Optimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.Optimizer
 
OptimizeTezProcContext - Class in org.apache.hadoop.hive.ql.parse
OptimizeTezProcContext.
OptimizeTezProcContext(HiveConf, ParseContext, Set<ReadEntity>, Set<WriteEntity>, Deque<Operator<?>>) - Constructor for class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 
OpTraits - Class in org.apache.hadoop.hive.ql.plan
 
OpTraits(List<List<String>>, int) - Constructor for class org.apache.hadoop.hive.ql.plan.OpTraits
 
OpTraitsRulesProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.metainfo.annotation
 
OpTraitsRulesProcFactory() - Constructor for class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory
 
OpTraitsRulesProcFactory.DefaultRule - Class in org.apache.hadoop.hive.ql.optimizer.metainfo.annotation
 
OpTraitsRulesProcFactory.DefaultRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.DefaultRule
 
OpTraitsRulesProcFactory.GroupByRule - Class in org.apache.hadoop.hive.ql.optimizer.metainfo.annotation
 
OpTraitsRulesProcFactory.GroupByRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.GroupByRule
 
OpTraitsRulesProcFactory.JoinRule - Class in org.apache.hadoop.hive.ql.optimizer.metainfo.annotation
 
OpTraitsRulesProcFactory.JoinRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.JoinRule
 
OpTraitsRulesProcFactory.MultiParentRule - Class in org.apache.hadoop.hive.ql.optimizer.metainfo.annotation
 
OpTraitsRulesProcFactory.MultiParentRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.MultiParentRule
 
OpTraitsRulesProcFactory.ReduceSinkRule - Class in org.apache.hadoop.hive.ql.optimizer.metainfo.annotation
 
OpTraitsRulesProcFactory.ReduceSinkRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.ReduceSinkRule
 
OpTraitsRulesProcFactory.SelectRule - Class in org.apache.hadoop.hive.ql.optimizer.metainfo.annotation
 
OpTraitsRulesProcFactory.SelectRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.SelectRule
 
OpTraitsRulesProcFactory.TableScanRule - Class in org.apache.hadoop.hive.ql.optimizer.metainfo.annotation
 
OpTraitsRulesProcFactory.TableScanRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.TableScanRule
 
opvec - Static variable in class org.apache.hadoop.hive.ql.exec.OperatorFactory
 
OpWalkerCtx - Class in org.apache.hadoop.hive.ql.optimizer.ppr
Context class for operator tree walker for partition pruner.
OpWalkerCtx(HashMap<TableScanOperator, ExprNodeDesc>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.OpWalkerCtx
Constructor.
OpWalkerInfo - Class in org.apache.hadoop.hive.ql.ppd
Context class for operator walker of predicate pushdown.
OpWalkerInfo(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
or(SearchArgument.TruthValue) - Method in enum org.apache.hadoop.hive.ql.io.sarg.SearchArgument.TruthValue
Compute logical or between the two values.
orBoolOperand(Boolean, Boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPrunerUtils
or 2 Boolean operands in the context of pruning match Operand one|Operand another | or result unknown | T | T unknown | F | unknown unknown | unknown | unknown T | T | T T | F | T T | unknown | unknown F | T | T F | F | F F | unknown | unknown
ORC_ACID_VERSION - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater
 
ORC_GET_SPLITS - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
OrcFile - Class in org.apache.hadoop.hive.ql.io.orc
Contains factory methods to read or write ORC files.
OrcFile.OrcTableProperties - Enum in org.apache.hadoop.hive.ql.io.orc
Enum container for all orc table properties.
OrcFile.ReaderOptions - Class in org.apache.hadoop.hive.ql.io.orc
 
OrcFile.Version - Enum in org.apache.hadoop.hive.ql.io.orc
Create a version number for the ORC file format, so that we can add non-forward compatible changes in the future.
OrcFile.WriterCallback - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcFile.WriterContext - Interface in org.apache.hadoop.hive.ql.io.orc
 
OrcFile.WriterOptions - Class in org.apache.hadoop.hive.ql.io.orc
Options for creating ORC file writers.
OrcInputFormat - Class in org.apache.hadoop.hive.ql.io.orc
A MapReduce/Hive input format for ORC files.
OrcInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
 
OrcNewInputFormat - Class in org.apache.hadoop.hive.ql.io.orc
An InputFormat for ORC files.
OrcNewInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcNewInputFormat
 
OrcNewOutputFormat - Class in org.apache.hadoop.hive.ql.io.orc
An OutputFormat that writes ORC files.
OrcNewOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcNewOutputFormat
 
OrcNewSplit - Class in org.apache.hadoop.hive.ql.io.orc
OrcFileSplit.
OrcNewSplit(OrcSplit) - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcNewSplit
 
orcOptions(OrcFile.WriterOptions) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater.OrcOptions
 
OrcOutputFormat - Class in org.apache.hadoop.hive.ql.io.orc
A Hive OutputFormat for ORC files.
OrcOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcOutputFormat
 
OrcRawRecordMerger - Class in org.apache.hadoop.hive.ql.io.orc
Merges a base and a list of delta files together into a single stream of events.
OrcRecordUpdater - Class in org.apache.hadoop.hive.ql.io.orc
A RecordUpdater where the files are stored as ORC.
OrcRecordUpdater.OrcOptions - Class in org.apache.hadoop.hive.ql.io.orc
An extension to AcidOutputFormat that allows users to add additional options.
OrcRecordUpdater.OrcOptions(Configuration) - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater.OrcOptions
 
OrcSerde - Class in org.apache.hadoop.hive.ql.io.orc
A serde class for ORC.
OrcSerde() - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcSerde
 
OrcSplit - Class in org.apache.hadoop.hive.ql.io.orc
OrcFileSplit.
OrcSplit(Path, long, long, String[], ReaderImpl.FileMetaInfo, boolean, boolean, List<Long>) - Constructor for class org.apache.hadoop.hive.ql.io.orc.OrcSplit
 
OrcStruct - Class in org.apache.hadoop.hive.ql.io.orc
 
OrderDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
OrderDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.OrderDef
 
OrderDef(PartitionDef) - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.OrderDef
 
OrderExpressionDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
OrderExpressionDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.OrderExpressionDef
 
OrderExpressionDef(PTFExpressionDef) - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.OrderExpressionDef
 
org.apache.hadoop.hive.ql - package org.apache.hadoop.hive.ql
 
org.apache.hadoop.hive.ql.exec - package org.apache.hadoop.hive.ql.exec
Hive QL execution tasks, operators, functions and other handlers.
org.apache.hadoop.hive.ql.exec.errors - package org.apache.hadoop.hive.ql.exec.errors
Generates execution error messages using heuristics.
org.apache.hadoop.hive.ql.exec.mapjoin - package org.apache.hadoop.hive.ql.exec.mapjoin
 
org.apache.hadoop.hive.ql.exec.mr - package org.apache.hadoop.hive.ql.exec.mr
 
org.apache.hadoop.hive.ql.exec.persistence - package org.apache.hadoop.hive.ql.exec.persistence
 
org.apache.hadoop.hive.ql.exec.tez - package org.apache.hadoop.hive.ql.exec.tez
 
org.apache.hadoop.hive.ql.exec.tez.tools - package org.apache.hadoop.hive.ql.exec.tez.tools
 
org.apache.hadoop.hive.ql.exec.vector - package org.apache.hadoop.hive.ql.exec.vector
 
org.apache.hadoop.hive.ql.exec.vector.expressions - package org.apache.hadoop.hive.ql.exec.vector.expressions
 
org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates - package org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates
 
org.apache.hadoop.hive.ql.exec.vector.udf - package org.apache.hadoop.hive.ql.exec.vector.udf
 
org.apache.hadoop.hive.ql.history - package org.apache.hadoop.hive.ql.history
 
org.apache.hadoop.hive.ql.hooks - package org.apache.hadoop.hive.ql.hooks
 
org.apache.hadoop.hive.ql.index - package org.apache.hadoop.hive.ql.index
 
org.apache.hadoop.hive.ql.index.bitmap - package org.apache.hadoop.hive.ql.index.bitmap
 
org.apache.hadoop.hive.ql.index.compact - package org.apache.hadoop.hive.ql.index.compact
 
org.apache.hadoop.hive.ql.io - package org.apache.hadoop.hive.ql.io
 
org.apache.hadoop.hive.ql.io.avro - package org.apache.hadoop.hive.ql.io.avro
 
org.apache.hadoop.hive.ql.io.orc - package org.apache.hadoop.hive.ql.io.orc
The Optimized Row Columnar (ORC) File Format.
org.apache.hadoop.hive.ql.io.parquet - package org.apache.hadoop.hive.ql.io.parquet
 
org.apache.hadoop.hive.ql.io.parquet.convert - package org.apache.hadoop.hive.ql.io.parquet.convert
 
org.apache.hadoop.hive.ql.io.parquet.read - package org.apache.hadoop.hive.ql.io.parquet.read
 
org.apache.hadoop.hive.ql.io.parquet.serde - package org.apache.hadoop.hive.ql.io.parquet.serde
 
org.apache.hadoop.hive.ql.io.parquet.serde.primitive - package org.apache.hadoop.hive.ql.io.parquet.serde.primitive
 
org.apache.hadoop.hive.ql.io.parquet.writable - package org.apache.hadoop.hive.ql.io.parquet.writable
 
org.apache.hadoop.hive.ql.io.parquet.write - package org.apache.hadoop.hive.ql.io.parquet.write
 
org.apache.hadoop.hive.ql.io.rcfile.merge - package org.apache.hadoop.hive.ql.io.rcfile.merge
 
org.apache.hadoop.hive.ql.io.rcfile.stats - package org.apache.hadoop.hive.ql.io.rcfile.stats
 
org.apache.hadoop.hive.ql.io.rcfile.truncate - package org.apache.hadoop.hive.ql.io.rcfile.truncate
 
org.apache.hadoop.hive.ql.io.sarg - package org.apache.hadoop.hive.ql.io.sarg
 
org.apache.hadoop.hive.ql.lib - package org.apache.hadoop.hive.ql.lib
 
org.apache.hadoop.hive.ql.lockmgr - package org.apache.hadoop.hive.ql.lockmgr
Hive Lock Manager interfaces and some custom implmentations
org.apache.hadoop.hive.ql.lockmgr.zookeeper - package org.apache.hadoop.hive.ql.lockmgr.zookeeper
 
org.apache.hadoop.hive.ql.log - package org.apache.hadoop.hive.ql.log
 
org.apache.hadoop.hive.ql.metadata - package org.apache.hadoop.hive.ql.metadata
 
org.apache.hadoop.hive.ql.metadata.formatting - package org.apache.hadoop.hive.ql.metadata.formatting
 
org.apache.hadoop.hive.ql.optimizer - package org.apache.hadoop.hive.ql.optimizer
 
org.apache.hadoop.hive.ql.optimizer.correlation - package org.apache.hadoop.hive.ql.optimizer.correlation
 
org.apache.hadoop.hive.ql.optimizer.index - package org.apache.hadoop.hive.ql.optimizer.index
 
org.apache.hadoop.hive.ql.optimizer.lineage - package org.apache.hadoop.hive.ql.optimizer.lineage
 
org.apache.hadoop.hive.ql.optimizer.listbucketingpruner - package org.apache.hadoop.hive.ql.optimizer.listbucketingpruner
 
org.apache.hadoop.hive.ql.optimizer.metainfo.annotation - package org.apache.hadoop.hive.ql.optimizer.metainfo.annotation
 
org.apache.hadoop.hive.ql.optimizer.optiq - package org.apache.hadoop.hive.ql.optimizer.optiq
 
org.apache.hadoop.hive.ql.optimizer.optiq.cost - package org.apache.hadoop.hive.ql.optimizer.optiq.cost
 
org.apache.hadoop.hive.ql.optimizer.optiq.reloperators - package org.apache.hadoop.hive.ql.optimizer.optiq.reloperators
 
org.apache.hadoop.hive.ql.optimizer.optiq.rules - package org.apache.hadoop.hive.ql.optimizer.optiq.rules
 
org.apache.hadoop.hive.ql.optimizer.optiq.stats - package org.apache.hadoop.hive.ql.optimizer.optiq.stats
 
org.apache.hadoop.hive.ql.optimizer.optiq.translator - package org.apache.hadoop.hive.ql.optimizer.optiq.translator
 
org.apache.hadoop.hive.ql.optimizer.pcr - package org.apache.hadoop.hive.ql.optimizer.pcr
 
org.apache.hadoop.hive.ql.optimizer.physical - package org.apache.hadoop.hive.ql.optimizer.physical
 
org.apache.hadoop.hive.ql.optimizer.physical.index - package org.apache.hadoop.hive.ql.optimizer.physical.index
 
org.apache.hadoop.hive.ql.optimizer.ppr - package org.apache.hadoop.hive.ql.optimizer.ppr
 
org.apache.hadoop.hive.ql.optimizer.stats.annotation - package org.apache.hadoop.hive.ql.optimizer.stats.annotation
 
org.apache.hadoop.hive.ql.optimizer.unionproc - package org.apache.hadoop.hive.ql.optimizer.unionproc
 
org.apache.hadoop.hive.ql.parse - package org.apache.hadoop.hive.ql.parse
 
org.apache.hadoop.hive.ql.parse.authorization - package org.apache.hadoop.hive.ql.parse.authorization
 
org.apache.hadoop.hive.ql.plan - package org.apache.hadoop.hive.ql.plan
 
org.apache.hadoop.hive.ql.plan.ptf - package org.apache.hadoop.hive.ql.plan.ptf
 
org.apache.hadoop.hive.ql.ppd - package org.apache.hadoop.hive.ql.ppd
 
org.apache.hadoop.hive.ql.processors - package org.apache.hadoop.hive.ql.processors
 
org.apache.hadoop.hive.ql.security - package org.apache.hadoop.hive.ql.security
 
org.apache.hadoop.hive.ql.security.authorization - package org.apache.hadoop.hive.ql.security.authorization
 
org.apache.hadoop.hive.ql.security.authorization.plugin - package org.apache.hadoop.hive.ql.security.authorization.plugin
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd - package org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
 
org.apache.hadoop.hive.ql.session - package org.apache.hadoop.hive.ql.session
 
org.apache.hadoop.hive.ql.stats - package org.apache.hadoop.hive.ql.stats
 
org.apache.hadoop.hive.ql.stats.fs - package org.apache.hadoop.hive.ql.stats.fs
 
org.apache.hadoop.hive.ql.stats.jdbc - package org.apache.hadoop.hive.ql.stats.jdbc
 
org.apache.hadoop.hive.ql.tools - package org.apache.hadoop.hive.ql.tools
 
org.apache.hadoop.hive.ql.txn.compactor - package org.apache.hadoop.hive.ql.txn.compactor
 
org.apache.hadoop.hive.ql.udf - package org.apache.hadoop.hive.ql.udf
 
org.apache.hadoop.hive.ql.udf.generic - package org.apache.hadoop.hive.ql.udf.generic
Standard toolkit and framework for generic User-defined functions.
org.apache.hadoop.hive.ql.udf.ptf - package org.apache.hadoop.hive.ql.udf.ptf
 
org.apache.hadoop.hive.ql.udf.xml - package org.apache.hadoop.hive.ql.udf.xml
 
org.apache.hadoop.hive.ql.util - package org.apache.hadoop.hive.ql.util
 
out - Variable in class org.apache.hadoop.hive.ql.session.SessionState
 
outExpr - Variable in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.NodeInfoWrapper
 
OUTPUT_FORMATTER - Static variable in class org.apache.hadoop.hive.ql.exec.ListSinkOperator
 
OUTPUT_PROTOCOL - Static variable in class org.apache.hadoop.hive.ql.exec.ListSinkOperator
 
outputAST(String, PrintStream, boolean, int) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
outputDependencies(PrintStream, boolean, boolean, List<Task>) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
outputs - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
outputs - Variable in class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 
outputStagePlans(PrintStream, List<Task>, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 

P

Pair<T1,T2> - Class in org.apache.hadoop.hive.ql.optimizer.optiq
 
Pair(T1, T2) - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.Pair
 
parentOfRoot - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
PARQUET_HIVE_SCHEMA - Static variable in class org.apache.hadoop.hive.ql.io.parquet.write.DataWritableWriteSupport
 
ParquetByteInspector - Class in org.apache.hadoop.hive.ql.io.parquet.serde.primitive
The ParquetByteInspector can inspect both ByteWritables and IntWritables into bytes.
parquetByteInspector - Static variable in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetPrimitiveInspectorFactory
 
ParquetHiveArrayInspector - Class in org.apache.hadoop.hive.ql.io.parquet.serde
The ParquetHiveArrayInspector will inspect an ArrayWritable, considering it as an Hive array.
It can also inspect a List if Hive decides to inspect the result of an inspection.
ParquetHiveArrayInspector(ObjectInspector) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveArrayInspector
 
ParquetHiveSerDe - Class in org.apache.hadoop.hive.ql.io.parquet.serde
A ParquetHiveSerDe for Hive (with the deprecated package mapred)
ParquetHiveSerDe() - Constructor for class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe
 
ParquetPrimitiveInspectorFactory - Class in org.apache.hadoop.hive.ql.io.parquet.serde.primitive
The ParquetPrimitiveInspectorFactory allows us to be sure that the same object is inspected by the same inspector.
ParquetRecordReaderWrapper - Class in org.apache.hadoop.hive.ql.io.parquet.read
 
ParquetRecordReaderWrapper(ParquetInputFormat<ArrayWritable>, InputSplit, JobConf, Reporter) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.read.ParquetRecordReaderWrapper
 
ParquetRecordReaderWrapper(ParquetInputFormat<ArrayWritable>, InputSplit, JobConf, Reporter, ProjectionPusher) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.read.ParquetRecordReaderWrapper
 
ParquetRecordWriterWrapper - Class in org.apache.hadoop.hive.ql.io.parquet.write
 
ParquetRecordWriterWrapper(OutputFormat<Void, ArrayWritable>, JobConf, String, Progressable) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.write.ParquetRecordWriterWrapper
 
parquetShortInspector - Static variable in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetPrimitiveInspectorFactory
 
ParquetShortInspector - Class in org.apache.hadoop.hive.ql.io.parquet.serde.primitive
The ParquetShortInspector can inspect both ShortWritables and IntWritables into shorts.
parquetStringInspector - Static variable in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetPrimitiveInspectorFactory
 
ParquetStringInspector - Class in org.apache.hadoop.hive.ql.io.parquet.serde.primitive
The ParquetStringInspector inspects a BinaryWritable to give a Text or String.
PARSE - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
parse(String) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver
 
parse(String, Context) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver
 
parse(String, Context, boolean) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver
Parses a command, optionally assigning the parser's token stream to the given context.
parseBaseBucketFilename(Path, Configuration) - Static method in class org.apache.hadoop.hive.ql.io.AcidUtils
Parse a bucket filename back into the options that would have created the file.
parseContext - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
parseContext - Variable in class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 
ParseContext - Class in org.apache.hadoop.hive.ql.parse
Parse Context: The current parse context.
ParseContext() - Constructor for class org.apache.hadoop.hive.ql.parse.ParseContext
 
ParseContext(HiveConf, QB, ASTNode, HashMap<TableScanOperator, ExprNodeDesc>, HashMap<TableScanOperator, PrunedPartitionList>, HashMap<String, Operator<? extends OperatorDesc>>, HashMap<String, Operator<? extends OperatorDesc>>, LinkedHashMap<Operator<? extends OperatorDesc>, OpParseContext>, Map<JoinOperator, QBJoinTree>, Map<SMBMapJoinOperator, QBJoinTree>, HashMap<TableScanOperator, Table>, HashMap<TableScanOperator, Map<String, String>>, Map<FileSinkOperator, Table>, List<LoadTableDesc>, List<LoadFileDesc>, Context, HashMap<String, String>, int, UnionProcContext, List<AbstractMapJoinOperator<? extends MapJoinDesc>>, Map<GroupByOperator, Set<String>>, Map<String, PrunedPartitionList>, HashMap<TableScanOperator, FilterDesc.sampleDesc>, GlobalLimitCtx, HashMap<String, SplitSample>, HashSet<ReadEntity>, List<Task<? extends Serializable>>, Map<TableScanOperator, Map<String, ExprNodeDesc>>, Map<String, ReadEntity>, List<ReduceSinkOperator>, QueryProperties) - Constructor for class org.apache.hadoop.hive.ql.parse.ParseContext
 
ParseDriver - Class in org.apache.hadoop.hive.ql.parse
ParseDriver.
ParseDriver() - Constructor for class org.apache.hadoop.hive.ql.parse.ParseDriver
 
ParseDriver.ANTLRNoCaseStringStream - Class in org.apache.hadoop.hive.ql.parse
ANTLRNoCaseStringStream.
ParseDriver.ANTLRNoCaseStringStream(String) - Constructor for class org.apache.hadoop.hive.ql.parse.ParseDriver.ANTLRNoCaseStringStream
 
ParseDriver.HiveLexerX - Class in org.apache.hadoop.hive.ql.parse
HiveLexerX.
ParseDriver.HiveLexerX() - Constructor for class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveLexerX
 
ParseDriver.HiveLexerX(CharStream) - Constructor for class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveLexerX
 
ParseError - Class in org.apache.hadoop.hive.ql.parse
 
ParseException - Exception in org.apache.hadoop.hive.ql.parse
ParseException.
ParseException(ArrayList<ParseError>) - Constructor for exception org.apache.hadoop.hive.ql.parse.ParseException
 
parseHiveHistory(String, HiveHistory.Listener) - Static method in class org.apache.hadoop.hive.ql.history.HiveHistoryUtil
Parses history file and calls call back functions.
parseSelect(String, Context) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver
 
parseSelect(String) - Static method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
ParseUtils - Class in org.apache.hadoop.hive.ql.parse
Library of utility functions used in the parse code.
PART_STAT_ID_COLUMN_NAME - Static variable in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsSetupConstants
 
PART_STAT_RAW_DATA_SIZE_COLUMN_NAME - Static variable in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsSetupConstants
 
PART_STAT_ROW_COUNT_COLUMN_NAME - Static variable in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsSetupConstants
 
PART_STAT_TABLE_NAME - Static variable in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsSetupConstants
 
PART_STAT_TIMESTAMP_COLUMN_NAME - Static variable in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsSetupConstants
 
PartExprEvalUtils - Class in org.apache.hadoop.hive.ql.optimizer.ppr
 
PartExprEvalUtils() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.PartExprEvalUtils
 
partHandle - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
PartialScanMapper - Class in org.apache.hadoop.hive.ql.io.rcfile.stats
PartialScanMapper.
PartialScanMapper() - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanMapper
 
PartialScanTask - Class in org.apache.hadoop.hive.ql.io.rcfile.stats
PartialScanTask.
PartialScanTask() - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanTask
 
PartialScanWork - Class in org.apache.hadoop.hive.ql.io.rcfile.stats
Partial Scan Work.
PartialScanWork() - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanWork
 
PartialScanWork(List<Path>) - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanWork
 
Partition - Class in org.apache.hadoop.hive.ql.metadata
A Hive Table Partition: is a fundamental storage unit within a Table.
Partition() - Constructor for class org.apache.hadoop.hive.ql.metadata.Partition
Used only for serialization.
Partition(Table) - Constructor for class org.apache.hadoop.hive.ql.metadata.Partition
create an empty partition.
Partition(Table, Partition) - Constructor for class org.apache.hadoop.hive.ql.metadata.Partition
 
Partition(Table, Map<String, String>, Path) - Constructor for class org.apache.hadoop.hive.ql.metadata.Partition
Create partition object with the given info.
PARTITION_RETRIEVING - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
PartitionConditionRemover - Class in org.apache.hadoop.hive.ql.optimizer.pcr
The transformation step that does partition condition remover.
PartitionConditionRemover() - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PartitionConditionRemover
 
PartitionDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
PartitionDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.PartitionDef
 
PartitionDesc - Class in org.apache.hadoop.hive.ql.plan
PartitionDesc.
PartitionDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
PartitionDesc(TableDesc, LinkedHashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
PartitionDesc(Partition) - Constructor for class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
PartitionDesc(Partition, TableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
PartitionedTableFunctionDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
PartitionedTableFunctionDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
PartitionExpressionForMetastore - Class in org.apache.hadoop.hive.ql.optimizer.ppr
The basic implementation of PartitionExpressionProxy that uses ql package classes.
PartitionExpressionForMetastore() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionExpressionForMetastore
 
PartitionKeySampler - Class in org.apache.hadoop.hive.ql.exec
 
PartitionKeySampler() - Constructor for class org.apache.hadoop.hive.ql.exec.PartitionKeySampler
 
PartitionPruner - Class in org.apache.hadoop.hive.ql.optimizer.ppr
The transformation step that does partition pruning.
PartitionPruner() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
 
partitions - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
PartitionTableFunctionDescription - Annotation Type in org.apache.hadoop.hive.ql.exec
 
partSpec - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
passExecContext(ExecMapperContext) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Pass the execContext reference to every child operator
PcrExprProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.pcr
The processor context for partition condition remover.
PcrExprProcCtx(String, List<Partition>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcCtx
 
PcrExprProcCtx(String, List<Partition>, List<VirtualColumn>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcCtx
 
PcrExprProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.pcr
Expression processor factory for partition condition removing.
PcrExprProcFactory.ColumnExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.pcr
Processor for column expressions.
PcrExprProcFactory.ColumnExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.ColumnExprProcessor
 
PcrExprProcFactory.DefaultExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.pcr
Processor for constants and null expressions.
PcrExprProcFactory.DefaultExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.DefaultExprProcessor
 
PcrExprProcFactory.FieldExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.pcr
FieldExprProcessor.
PcrExprProcFactory.FieldExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.FieldExprProcessor
 
PcrExprProcFactory.GenericFuncExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.pcr
Processor for Generic functions If it is AND, OR or NOT, we replace the node to be the constant true or false if we are sure the result from children, or cut one of the child if we know partial results.
PcrExprProcFactory.GenericFuncExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.GenericFuncExprProcessor
 
PcrExprProcFactory.NodeInfoWrapper - Class in org.apache.hadoop.hive.ql.optimizer.pcr
 
PcrExprProcFactory.NodeInfoWrapper(PcrExprProcFactory.WalkState, Boolean[], ExprNodeDesc) - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.NodeInfoWrapper
 
PcrExprProcFactory.WalkState - Enum in org.apache.hadoop.hive.ql.optimizer.pcr
 
PcrOpProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.pcr
PcrOpProcFactory contains processors that process expression tree of filter operators following table scan operators.
PcrOpProcFactory.DefaultPCR - Class in org.apache.hadoop.hive.ql.optimizer.pcr
Default processor which does nothing
PcrOpProcFactory.DefaultPCR() - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpProcFactory.DefaultPCR
 
PcrOpProcFactory.FilterPCR - Class in org.apache.hadoop.hive.ql.optimizer.pcr
Remove partition condition in a filter operator when possible.
PcrOpProcFactory.FilterPCR() - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpProcFactory.FilterPCR
 
PcrOpWalkerCtx - Class in org.apache.hadoop.hive.ql.optimizer.pcr
Context class for operator tree walker for partition condition remover.
PcrOpWalkerCtx(ParseContext, List<PcrOpWalkerCtx.OpToDeleteInfo>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpWalkerCtx
Constructor.
PcrOpWalkerCtx.OpToDeleteInfo - Class in org.apache.hadoop.hive.ql.optimizer.pcr
 
PcrOpWalkerCtx.OpToDeleteInfo(Operator<? extends OperatorDesc>, FilterOperator) - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpWalkerCtx.OpToDeleteInfo
 
PerfLogBegin(String, String) - Method in class org.apache.hadoop.hive.ql.log.PerfLogger
Call this function when you start to measure time spent by a piece of code.
PerfLogEnd(String, String) - Method in class org.apache.hadoop.hive.ql.log.PerfLogger
Call this function in correspondence of PerfLogBegin to mark the end of the measurement.
PerfLogger - Class in org.apache.hadoop.hive.ql.log
PerfLogger.
PerfLogger() - Constructor for class org.apache.hadoop.hive.ql.log.PerfLogger
 
persist(ObjectOutputStream, MapJoinTableContainer) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainerSerDe
 
persistDummyTable(ObjectOutputStream) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainerSerDe
 
PhysicalContext - Class in org.apache.hadoop.hive.ql.optimizer.physical
physical context used by physical resolvers.
PhysicalContext(HiveConf, ParseContext, Context, List<Task<? extends Serializable>>, Task<? extends Serializable>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
PhysicalOptimizer - Class in org.apache.hadoop.hive.ql.optimizer.physical
A hierarchy physical optimizer, which contains a list of PhysicalPlanResolver.
PhysicalOptimizer(PhysicalContext, HiveConf) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalOptimizer
 
PhysicalPlanResolver - Interface in org.apache.hadoop.hive.ql.optimizer.physical
Physical plan optimization interface.
PidDailyRollingFileAppender - Class in org.apache.hadoop.hive.ql.log
 
PidDailyRollingFileAppender() - Constructor for class org.apache.hadoop.hive.ql.log.PidDailyRollingFileAppender
 
PlanUtils - Class in org.apache.hadoop.hive.ql.plan
PlanUtils.
PlanUtils.ExpressionTypes - Enum in org.apache.hadoop.hive.ql.plan
ExpressionTypes.
plus(RelOptCost) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCost
 
pollFinished() - Method in class org.apache.hadoop.hive.ql.DriverContext
Polls running tasks to see if a task has ended.
populateJoinKeyValue(List<ExprNodeEvaluator>[], Map<Byte, List<ExprNodeDesc>>, int) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
populateJoinKeyValue(List<ExprNodeEvaluator>[], Map<Byte, List<ExprNodeDesc>>, Byte[], int) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
populateVirtualColumnValues(ExecMapperContext, List<VirtualColumn>, Writable[], Deserializer) - Static method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
PosModDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
PosModDoubleToDouble(int, double, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.PosModDoubleToDouble
 
PosModDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.PosModDoubleToDouble
 
PosModLongToLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
PosModLongToLong(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.PosModLongToLong
 
PosModLongToLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.PosModLongToLong
 
POST_HOOK - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
postAnalyze(HiveSemanticAnalyzerHookContext, List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.parse.AbstractSemanticAnalyzerHook
 
postAnalyze(HiveSemanticAnalyzerHookContext, List<Task<? extends Serializable>>) - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHook
Invoked after Hive performs its own semantic analysis on a statement (including optimization).
postDriverRun(HiveDriverRunHookContext) - Method in interface org.apache.hadoop.hive.ql.HiveDriverRunHook
Invoked after Hive performs any processing of a command, just before a response is returned to the entity calling the Driver.
postDriverRun(HiveDriverRunHookContext) - Method in class org.apache.hadoop.hive.ql.hooks.DriverTestHook
 
PostExecute - Interface in org.apache.hadoop.hive.ql.hooks
The post execute hook interface.
PostExecutePrinter - Class in org.apache.hadoop.hive.ql.hooks
Implementation of a post execute hook that simply prints out its parameters to standard output.
PostExecutePrinter() - Constructor for class org.apache.hadoop.hive.ql.hooks.PostExecutePrinter
 
PostExecutePrinter.DependencyKeyComp - Class in org.apache.hadoop.hive.ql.hooks
 
PostExecutePrinter.DependencyKeyComp() - Constructor for class org.apache.hadoop.hive.ql.hooks.PostExecutePrinter.DependencyKeyComp
 
postHook(Set<String>, String) - Method in interface org.apache.hadoop.hive.ql.session.SessionState.ResourceHook
 
PRE_HOOK - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
preAnalyze(HiveSemanticAnalyzerHookContext, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.AbstractSemanticAnalyzerHook
 
preAnalyze(HiveSemanticAnalyzerHookContext, ASTNode) - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHook
Invoked before Hive performs its own semantic analysis on a statement.
PreCBOOptimizer - Class in org.apache.hadoop.hive.ql.optimizer
 
PreCBOOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.PreCBOOptimizer
 
preceedingWork - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
precision - Variable in class org.apache.hadoop.hive.ql.exec.vector.DecimalColumnVector
 
PredicateLeaf - Interface in org.apache.hadoop.hive.ql.io.sarg
The primitive predicates that form a SearchArgument.
PredicateLeaf.Operator - Enum in org.apache.hadoop.hive.ql.io.sarg
The possible operators for predicates.
PredicateLeaf.Type - Enum in org.apache.hadoop.hive.ql.io.sarg
The possible types for sargs.
PredicatePushDown - Class in org.apache.hadoop.hive.ql.ppd
Implements predicate pushdown.
PredicatePushDown() - Constructor for class org.apache.hadoop.hive.ql.ppd.PredicatePushDown
 
PredicateTransitivePropagate - Class in org.apache.hadoop.hive.ql.ppd
propagates filters to other aliases based on join condition
PredicateTransitivePropagate() - Constructor for class org.apache.hadoop.hive.ql.ppd.PredicateTransitivePropagate
 
preDriverRun(HiveDriverRunHookContext) - Method in interface org.apache.hadoop.hive.ql.HiveDriverRunHook
Invoked before Hive begins any processing of a command in the Driver, notably before compilation and any customizable performance logging.
preDriverRun(HiveDriverRunHookContext) - Method in class org.apache.hadoop.hive.ql.hooks.DriverTestHook
 
PreExecute - Interface in org.apache.hadoop.hive.ql.hooks
The pre execute hook interface.
PreExecutePrinter - Class in org.apache.hadoop.hive.ql.hooks
Implementation of a pre execute hook that simply prints out its parameters to standard output.
PreExecutePrinter() - Constructor for class org.apache.hadoop.hive.ql.hooks.PreExecutePrinter
 
preFooterWrite(OrcFile.WriterContext) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterCallback
 
preHook(Set<String>, String) - Method in interface org.apache.hadoop.hive.ql.session.SessionState.ResourceHook
 
preorderMap(Operator.OperatorFunc) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
PreOrderWalker - Class in org.apache.hadoop.hive.ql.lib
base class for operator graph walker this class takes list of starting ops and walks them one by one.
PreOrderWalker(Dispatcher) - Constructor for class org.apache.hadoop.hive.ql.lib.PreOrderWalker
Constructor.
prepare(QueryPlan) - Method in class org.apache.hadoop.hive.ql.DriverContext
 
prepare(TaskRunner) - Method in class org.apache.hadoop.hive.ql.DriverContext
 
prepare(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF.DeferredJavaObject
 
prepare(int) - Method in interface org.apache.hadoop.hive.ql.udf.generic.GenericUDF.DeferredObject
 
prepareConstant() - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
prepareExpr(ExprNodeGenericFuncDesc, List<String>) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartExprEvalUtils
 
prepareForRead(Configuration, Map<String, String>, MessageType, ReadSupport.ReadContext) - Method in class org.apache.hadoop.hive.ql.io.parquet.read.DataWritableReadSupport
It creates the hive read support to interpret data from parquet to hive
prepareForWrite(RecordConsumer) - Method in class org.apache.hadoop.hive.ql.io.parquet.write.DataWritableWriteSupport
 
prepareRetry() - Method in class org.apache.hadoop.hive.ql.lockmgr.DbLockManager
 
prepareRetry() - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
prepareRetry() - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
prepareRetry() - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
prepareWithRetry(Connection, String, int, int) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Retry preparing a SQL statement with random backoff (same as the one implemented in HDFS-767).
prependPathComponent(String) - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator.PathFinder
Appends the specified component to the path list.
preStripeWrite(OrcFile.WriterContext) - Method in interface org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterCallback
 
PRETTY_MAX_INTERCOL_SPACING - Static variable in class org.apache.hadoop.hive.ql.metadata.formatting.MetaDataPrettyFormatUtils
 
primes - Static variable in class org.apache.hadoop.hive.ql.exec.vector.expressions.CuckooSetLong
 
primitive1() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
primitive2() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
PRIMITIVE_BYTE - Static variable in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
PRIMITIVES1 - Static variable in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
PRIMITIVES2 - Static variable in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
PrincipalDesc - Class in org.apache.hadoop.hive.ql.plan
 
PrincipalDesc(String, PrincipalType) - Constructor for class org.apache.hadoop.hive.ql.plan.PrincipalDesc
 
PrincipalDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.PrincipalDesc
 
print(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
print(String) - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
printError(String) - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
printError(String, String) - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
printInfo(String) - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
printInfo(String, String) - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
printNumDistinctValueEstimator() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
PrintOpTreeProcessor - Class in org.apache.hadoop.hive.ql.parse
PrintOpTreeProcessor.
PrintOpTreeProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.PrintOpTreeProcessor
 
PrintOpTreeProcessor(PrintStream) - Constructor for class org.apache.hadoop.hive.ql.parse.PrintOpTreeProcessor
 
printRowCount(String) - Method in interface org.apache.hadoop.hive.ql.history.HiveHistory
 
printRowCount(String) - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
 
Privilege - Class in org.apache.hadoop.hive.ql.security.authorization
Privilege defines a privilege in Hive.
Privilege(PrivilegeType) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
Privilege() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
PrivilegeDesc - Class in org.apache.hadoop.hive.ql.plan
 
PrivilegeDesc(Privilege, List<String>) - Constructor for class org.apache.hadoop.hive.ql.plan.PrivilegeDesc
 
PrivilegeDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.PrivilegeDesc
 
PrivilegeObjectDesc - Class in org.apache.hadoop.hive.ql.plan
 
PrivilegeObjectDesc(boolean, String, HashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
PrivilegeObjectDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
PrivilegeRegistry - Class in org.apache.hadoop.hive.ql.security.authorization
PrivilegeRegistry is used to do privilege lookups.
PrivilegeRegistry() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.PrivilegeRegistry
 
PrivilegeScope - Enum in org.apache.hadoop.hive.ql.security.authorization
PrivilegeScope describes a hive defined privilege's scope (global/database/table/column).
PrivilegeType - Enum in org.apache.hadoop.hive.ql.security.authorization
Privilege type
process(Writable) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
process(Writable) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapOperator
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.lib.CompositeProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in interface org.apache.hadoop.hive.ql.lib.NodeProcessor
Generic process for all ops that don't have specific implementations.
process(WatchedEvent) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager.DummyWatcher
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.AbstractBucketJoinProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.AbstractSMBJoinProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketingSortingReduceSinkOptimizer.BucketSortReduceSinkProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketMapjoinProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerDefaultProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerFilterProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerGroupByProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerJoinProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerLateralViewForwardProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerLateralViewJoinProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerMapJoinProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerPTFProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerReduceSinkProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerSelectProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerTableScanProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ConvertJoinMapJoin
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.ReduceSinkDeDuplication.AbsctractReducerReducerProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRFileSink1
File Sink Operator encountered.
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMROperator
Reduce Scan encountered.
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRRedSink1
Reduce Sink encountered.
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRRedSink2
Reduce Scan encountered.
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRRedSink3
Reduce Scan encountered.
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRTableScan1
Table Sink encountered.
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRUnion1
Union Operator encountered .
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.SortGroupByProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.SortGroupBySkewProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory.ColumnExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory.DefaultExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory.GenericExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.DefaultLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.GroupByLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.JoinLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.LateralViewJoinLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.ReduceSinkLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.SelectLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.TableScanLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.TransformLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.UnionLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.CurrentMapJoin
Store the current mapjoin in the context.
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.Default
Nothing to do.
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinDefault
Store the mapjoin in a rejected list.
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinFS
Store the current mapjoin in a list of mapjoins followed by a filesink.
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.DefaultRule
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.GroupByRule
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.JoinRule
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.MultiParentRule
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.ReduceSinkRule
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.SelectRule
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactory.TableScanRule
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.ColumnExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.DefaultExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.FieldExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.GenericFuncExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpProcFactory.DefaultPCR
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpProcFactory.FilterPCR
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.DefaultInferrer
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.ExtractInferrer
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.FileSinkInferrer
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.ForwardingInferrer
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.GroupByInferrer
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.JoinInferrer
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.MultiGroupByInferrer
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactory.SelectInferrer
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.index.IndexWhereProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory.LocalMapJoinProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory.MapJoinFollowedByGroupByProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinProcFactory.SkewJoinDefaultProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinProcFactory.SkewJoinJoinProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactory.ColumnExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactory.DefaultExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactory.FieldExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactory.GenericFuncExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.PrunerOperatorFactory.DefaultPruner
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.PrunerOperatorFactory.FilterPruner
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ReduceSinkMapJoinProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner.DefaultPPR
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner.FilterPPR
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.SetReducerParallelism
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.SkewJoinOptimizer.SkewJoinProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.SortedMergeBucketMapjoinProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.SortedMergeJoinProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory.DefaultStatsRule
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory.FilterStatsRule
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory.GroupByStatsRule
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory.JoinStatsRule
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory.LimitStatsRule
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory.SelectStatsRule
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory.TableScanStatsRule
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory.MapRedUnion
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory.MapUnion
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory.NoUnion
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory.UnionNoProcessFile
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory.UnknownUnion
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.FileSinkProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.GenTezWork
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.PrintOpTreeProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.ProcessAnalyzeTable
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.TableAccessAnalyzer.GroupByProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.TableAccessAnalyzer.JoinProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.BoolExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.ColumnExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DateExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.NullExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.NumExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.StrExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.SubQueryExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory.ColumnExprProcessor
Converts the reference from child row resolver to current row resolver.
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory.DefaultExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory.FieldExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory.GenericFuncExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.DefaultPPD
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.FilterPPD
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.JoinerPPD
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.LateralViewForwardPPD
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.ScriptPPD
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.TableScanPPD
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.UDTFPPD
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.tools.LineageInfo
Implements the process method for the NodeProcessor interface.
process(Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTF
Give a set of arguments for the UDTF to process.
process(Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFExplode
 
process(Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFInline
 
process(Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFJSONTuple
 
process(Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFParseUrlTuple
 
process(Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFPosExplode
 
process(Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFStack
 
ProcessAnalyzeTable - Class in org.apache.hadoop.hive.ql.parse
ProcessAnalyzeTable sets up work for the several variants of analyze table (normal, no scan, partial scan.) The plan at this point will be a single table scan operator.
ProcessAnalyzeTable(GenTezUtils) - Constructor for class org.apache.hadoop.hive.ql.parse.ProcessAnalyzeTable
Injecting the utils in the constructor facilitates testing
processCurrentTask(MapRedTask, ConditionalTask, Context) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.AbstractJoinTaskDispatcher
 
processCurrentTask(MapRedTask, ConditionalTask, Context) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.CommonJoinTaskDispatcher
 
processCurrentTask(MapRedTask, ConditionalTask, Context) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SortMergeJoinTaskDispatcher
 
processFileSink(GenTezProcContext, FileSinkOperator) - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
processGByExpr(Node, Object) - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Function to do groupby subexpression elimination.
processGroup(int) - Method in class org.apache.hadoop.hive.ql.exec.MuxOperator
 
processGroup(int) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
processLogLine(String) - Method in interface org.apache.hadoop.hive.ql.exec.errors.ErrorHeuristic
Process the given log line.
processLogLine(String) - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.CollectOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.DummyStoreOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ExtractOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.FilterOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ForwardOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.HashTableDummyOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.JoinOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.LateralViewForwardOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.LateralViewJoinOperator
An important assumption for processOp() is that for a given row from the TS, the LVJ will first get the row from the left select operator, followed by all the corresponding rows from the UDTF operator.
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ListSinkOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.MuxOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Process the row.
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.PTFOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
Other than gathering statistics for the ANALYZE command, the table scan operator does not do anything special other than just forwarding the row.
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.UnionOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorFileSinkOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorFilterOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorLimitOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSMBMapJoinOperator
 
processRowSkewedIndex(RowSchema) - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
Match column in skewed column list and record position.
processSkewJoin(JoinOperator, Task<? extends Serializable>, ParseContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.GenMRSkewJoinProcessor
Create tasks for processing skew joins.
processVectorExpressions(List<ExprNodeDesc>, List<String>, VectorExpressionWriterFactory.SingleOIDClosure) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory
Creates the value writers for a column vector expression list.
processVectorExpressions(List<ExprNodeDesc>, VectorExpressionWriterFactory.ListOIDClosure) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory
Creates the value writers for a column vector expression list.
progress(RunningJob, JobClient, HiveTxnManager) - Method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
progressLocal(Process, String) - Method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
progressTask(String, Task<? extends Serializable>) - Method in interface org.apache.hadoop.hive.ql.history.HiveHistory
Logs progress of a task if ConfVars.HIVE_LOG_INCREMENTAL_PLAN_PROGRESS is set to true
progressTask(String, Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
 
projectedColumns - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
ProjectionPusher - Class in org.apache.hadoop.hive.ql.io.parquet
 
ProjectionPusher() - Constructor for class org.apache.hadoop.hive.ql.io.parquet.ProjectionPusher
 
projectionSize - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
propagateNullsColCol(ColumnVector, ColumnVector, ColumnVector, int[], int, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NullUtil
 
ProxyUserAuthenticator - Class in org.apache.hadoop.hive.ql.security
ProxyUserAuthenticator extends HadoopDefaultAuthenticator but honours a proxy config setting proxy.user.name instead of the current user if set.
ProxyUserAuthenticator() - Constructor for class org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator
 
prune(ParseContext, Partition, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPruner
Prunes to the directories which match the skewed keys in where clause.
prune(TableScanOperator, ParseContext, String) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
Get the partition list for the TS operator that satisfies the partition pruner condition.
prune(Partition, FilterDesc.sampleDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner
Prunes to get all the files in the partition that satisfy the TABLESAMPLE clause.
PRUNE_LISTING - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
PrunedPartitionList - Class in org.apache.hadoop.hive.ql.parse
The list of pruned partitions.
PrunedPartitionList(Table, Set<Partition>, boolean) - Constructor for class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
 
prunePartitionNames(List<String>, ExprNodeGenericFuncDesc, String, List<String>) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
Prunes partition names to see if they match the prune expression.
PrunerExpressionOperatorFactory - Class in org.apache.hadoop.hive.ql.optimizer
Expression processor factory for pruning.
PrunerExpressionOperatorFactory() - Constructor for class org.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactory
 
PrunerExpressionOperatorFactory.ColumnExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer
Processor for column expressions.
PrunerExpressionOperatorFactory.ColumnExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactory.ColumnExprProcessor
 
PrunerExpressionOperatorFactory.DefaultExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer
Processor for constants and null expressions.
PrunerExpressionOperatorFactory.DefaultExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactory.DefaultExprProcessor
 
PrunerExpressionOperatorFactory.FieldExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer
FieldExprProcessor.
PrunerExpressionOperatorFactory.FieldExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactory.FieldExprProcessor
 
PrunerExpressionOperatorFactory.GenericFuncExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer
If all children are candidates and refer only to one table alias then this expr is a candidate else it is not a candidate but its children could be final candidates.
PrunerExpressionOperatorFactory.GenericFuncExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactory.GenericFuncExprProcessor
 
PrunerOperatorFactory - Class in org.apache.hadoop.hive.ql.optimizer
Operator factory for pruning processing of operator graph We find all the filter operators that appear just beneath the table scan operators.
PrunerOperatorFactory() - Constructor for class org.apache.hadoop.hive.ql.optimizer.PrunerOperatorFactory
 
PrunerOperatorFactory.DefaultPruner - Class in org.apache.hadoop.hive.ql.optimizer
Default processor which just merges its children.
PrunerOperatorFactory.DefaultPruner() - Constructor for class org.apache.hadoop.hive.ql.optimizer.PrunerOperatorFactory.DefaultPruner
 
PrunerOperatorFactory.FilterPruner - Class in org.apache.hadoop.hive.ql.optimizer
Determines the partition pruner for the filter.
PrunerOperatorFactory.FilterPruner() - Constructor for class org.apache.hadoop.hive.ql.optimizer.PrunerOperatorFactory.FilterPruner
 
PrunerUtils - Class in org.apache.hadoop.hive.ql.optimizer
General utility common functions for the Pruner to do optimization.
PTFDesc - Class in org.apache.hadoop.hive.ql.plan
 
PTFDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.PTFDesc
 
PTFDeserializer - Class in org.apache.hadoop.hive.ql.plan
 
PTFDeserializer(PTFDesc, StructObjectInspector, HiveConf) - Constructor for class org.apache.hadoop.hive.ql.plan.PTFDeserializer
 
PTFExpressionDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
PTFExpressionDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.PTFExpressionDef
 
PTFExpressionDef(PTFExpressionDef) - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.PTFExpressionDef
 
PTFInputDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
PTFInputDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.PTFInputDef
 
PTFInvocationSpec - Class in org.apache.hadoop.hive.ql.parse
 
PTFInvocationSpec() - Constructor for class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec
 
PTFInvocationSpec.Order - Enum in org.apache.hadoop.hive.ql.parse
 
PTFInvocationSpec.OrderExpression - Class in org.apache.hadoop.hive.ql.parse
 
PTFInvocationSpec.OrderExpression() - Constructor for class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderExpression
 
PTFInvocationSpec.OrderExpression(PTFInvocationSpec.PartitionExpression) - Constructor for class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderExpression
 
PTFInvocationSpec.OrderSpec - Class in org.apache.hadoop.hive.ql.parse
 
PTFInvocationSpec.OrderSpec() - Constructor for class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderSpec
 
PTFInvocationSpec.OrderSpec(PTFInvocationSpec.PartitionSpec) - Constructor for class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderSpec
 
PTFInvocationSpec.PartitionedTableFunctionSpec - Class in org.apache.hadoop.hive.ql.parse
 
PTFInvocationSpec.PartitionedTableFunctionSpec() - Constructor for class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
PTFInvocationSpec.PartitionExpression - Class in org.apache.hadoop.hive.ql.parse
 
PTFInvocationSpec.PartitionExpression() - Constructor for class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionExpression
 
PTFInvocationSpec.PartitionExpression(PTFInvocationSpec.PartitionExpression) - Constructor for class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionExpression
 
PTFInvocationSpec.PartitioningSpec - Class in org.apache.hadoop.hive.ql.parse
 
PTFInvocationSpec.PartitioningSpec() - Constructor for class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitioningSpec
 
PTFInvocationSpec.PartitionSpec - Class in org.apache.hadoop.hive.ql.parse
 
PTFInvocationSpec.PartitionSpec() - Constructor for class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionSpec
 
PTFInvocationSpec.PTFInputSpec - Class in org.apache.hadoop.hive.ql.parse
 
PTFInvocationSpec.PTFInputSpec() - Constructor for class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFInputSpec
 
PTFInvocationSpec.PTFQueryInputSpec - Class in org.apache.hadoop.hive.ql.parse
 
PTFInvocationSpec.PTFQueryInputSpec() - Constructor for class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFQueryInputSpec
 
PTFInvocationSpec.PTFQueryInputType - Enum in org.apache.hadoop.hive.ql.parse
 
PTFOperator - Class in org.apache.hadoop.hive.ql.exec
 
PTFOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.PTFOperator
 
PTFPartition - Class in org.apache.hadoop.hive.ql.exec
 
PTFPartition.PTFPartitionIterator<T> - Interface in org.apache.hadoop.hive.ql.exec
 
PTFQueryInputDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
PTFQueryInputDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.PTFQueryInputDef
 
PTFRowContainer<Row extends List<Object>> - Class in org.apache.hadoop.hive.ql.exec.persistence
Extends the RowContainer functionality to provide random access getAt(i).
PTFRowContainer(int, Configuration, Reporter) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer
 
PTFRowContainer.PTFHiveSequenceFileOutputFormat<K,V> - Class in org.apache.hadoop.hive.ql.exec.persistence
 
PTFRowContainer.PTFHiveSequenceFileOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer.PTFHiveSequenceFileOutputFormat
 
PTFRowContainer.PTFSequenceFileInputFormat<K,V> - Class in org.apache.hadoop.hive.ql.exec.persistence
 
PTFRowContainer.PTFSequenceFileInputFormat() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer.PTFSequenceFileInputFormat
 
PTFRowContainer.PTFSequenceFileRecordReader<K,V> - Class in org.apache.hadoop.hive.ql.exec.persistence
 
PTFRowContainer.PTFSequenceFileRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer.PTFSequenceFileRecordReader
 
PTFTranslator - Class in org.apache.hadoop.hive.ql.parse
 
PTFTranslator() - Constructor for class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
PTFTranslator.ValidateNoLeadLag - Class in org.apache.hadoop.hive.ql.parse
 
PTFTranslator.ValidateNoLeadLag(String) - Constructor for class org.apache.hadoop.hive.ql.parse.PTFTranslator.ValidateNoLeadLag
 
PTFUtils - Class in org.apache.hadoop.hive.ql.exec
 
PTFUtils() - Constructor for class org.apache.hadoop.hive.ql.exec.PTFUtils
 
PTFUtils.Predicate<T> - Class in org.apache.hadoop.hive.ql.exec
 
PTFUtils.Predicate() - Constructor for class org.apache.hadoop.hive.ql.exec.PTFUtils.Predicate
 
PTFUtils.ReverseIterator<T> - Class in org.apache.hadoop.hive.ql.exec
 
PTFUtils.ReverseIterator(Iterator<T>) - Constructor for class org.apache.hadoop.hive.ql.exec.PTFUtils.ReverseIterator
 
publishStat(String, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.stats.CounterStatsPublisher
 
publishStat(String, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.stats.fs.FSStatsPublisher
 
publishStat(String, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsPublisher
 
publishStat(String, Map<String, String>) - Method in interface org.apache.hadoop.hive.ql.stats.StatsPublisher
This method publishes a given statistic into a disk storage, possibly HBase or MySQL.
pushedPredicate - Variable in class org.apache.hadoop.hive.ql.metadata.HiveStoragePredicateHandler.DecomposedPredicate
Portion of predicate to be evaluated by storage handler.
pushFilters(JobConf, TableScanOperator) - Static method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
pushProjectionsAndFilters(JobConf, Path) - Method in class org.apache.hadoop.hive.ql.io.parquet.ProjectionPusher
 
pushRow() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
Get the next row and push down it to operator tree.
put(MapJoinKey, MapJoinRowContainer) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
put(MapJoinKey, MapJoinRowContainer) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer
 
put(Object, Object, Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
put(String, Object) - Method in class org.apache.hadoop.hive.ql.metadata.formatting.MapBuilder
 
put(String, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.formatting.MapBuilder
 
put(String, int) - Method in class org.apache.hadoop.hive.ql.metadata.formatting.MapBuilder
 
put(String, long) - Method in class org.apache.hadoop.hive.ql.metadata.formatting.MapBuilder
 
put(String, T, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.formatting.MapBuilder
 
put(String, String, ColumnInfo) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
put(Operator<? extends OperatorDesc>, OpParseContext) - Method in class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
putColumnLevelRequiredPriv(Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
putDBLevelRequiredPriv(Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
putDependency(LineageInfo.DataContainer, FieldSchema, LineageInfo.Dependency) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo
Puts the dependency for a table, column tuple.
putDependency(Operator<? extends OperatorDesc>, ColumnInfo, LineageInfo.Dependency) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx.Index
Puts the dependency for an operator, columninfo tuple.
putExpression(ASTNode, ColumnInfo) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
Puts a resolver entry corresponding to a source expression which is to be used for identical expression recognition (e.g.
putInPool(T) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorUtilBatchObjectPool
 
putOpInsertMap(Operator<? extends OperatorDesc>, RowResolver, ParseContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
insert in the map for the operator to row resolver.
putOpInsertMap(Operator<T>, RowResolver) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
putPrunedPreds(Operator<? extends OperatorDesc>, ExprWalkerInfo) - Method in class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
putTableLevelRequiredPriv(Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
putUserLevelRequiredPriv(Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 

Q

QB - Class in org.apache.hadoop.hive.ql.parse
Implementation of the query block.
QB() - Constructor for class org.apache.hadoop.hive.ql.parse.QB
 
QB(String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.parse.QB
 
QBExpr - Class in org.apache.hadoop.hive.ql.parse
Implementation of the query block expression.
QBExpr(String) - Constructor for class org.apache.hadoop.hive.ql.parse.QBExpr
 
QBExpr(QB) - Constructor for class org.apache.hadoop.hive.ql.parse.QBExpr
 
QBExpr(QBExpr.Opcode, QBExpr, QBExpr) - Constructor for class org.apache.hadoop.hive.ql.parse.QBExpr
 
QBExpr.Opcode - Enum in org.apache.hadoop.hive.ql.parse
Opcode.
QBJoinTree - Class in org.apache.hadoop.hive.ql.parse
Internal representation of the join tree.
QBJoinTree() - Constructor for class org.apache.hadoop.hive.ql.parse.QBJoinTree
constructor.
QBMetaData - Class in org.apache.hadoop.hive.ql.parse
Implementation of the metadata information related to a query block.
QBMetaData() - Constructor for class org.apache.hadoop.hive.ql.parse.QBMetaData
 
QBParseInfo - Class in org.apache.hadoop.hive.ql.parse
Implementation of the parse information related to a query block.
QBParseInfo(String, boolean) - Constructor for class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
QBSubQuery - Class in org.apache.hadoop.hive.ql.parse
 
QBSubQuery(String, int, ASTNode, ASTNode, QBSubQuery.SubQueryTypeDef, ASTNode, Context) - Constructor for class org.apache.hadoop.hive.ql.parse.QBSubQuery
 
QBSubQuery.SubQueryType - Enum in org.apache.hadoop.hive.ql.parse
 
QBSubQuery.SubQueryTypeDef - Class in org.apache.hadoop.hive.ql.parse
 
QBSubQuery.SubQueryTypeDef(ASTNode, QBSubQuery.SubQueryType) - Constructor for class org.apache.hadoop.hive.ql.parse.QBSubQuery.SubQueryTypeDef
 
qualifyFunctionName(String, String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionUtils
 
quantile(double) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Gets an approximate quantile value from the current histogram.
QueryPlan - Class in org.apache.hadoop.hive.ql
QueryPlan can be serialized to disk so that we can restart/resume the progress of it in the future, either within or outside of the current jvm.
QueryPlan() - Constructor for class org.apache.hadoop.hive.ql.QueryPlan
 
QueryPlan(String, BaseSemanticAnalyzer, Long) - Constructor for class org.apache.hadoop.hive.ql.QueryPlan
 
QueryPlan(String, BaseSemanticAnalyzer, Long, String) - Constructor for class org.apache.hadoop.hive.ql.QueryPlan
 
QueryPlanTreeTransformation - Class in org.apache.hadoop.hive.ql.optimizer.correlation
QueryPlanTreeTransformation contains static methods used to transform the query plan tree (operator tree) based on the correlation we have detected by Correlation Optimizer.
QueryPlanTreeTransformation() - Constructor for class org.apache.hadoop.hive.ql.optimizer.correlation.QueryPlanTreeTransformation
 
QueryProperties - Class in org.apache.hadoop.hive.ql
QueryProperties.
QueryProperties() - Constructor for class org.apache.hadoop.hive.ql.QueryProperties
 
QUOTE - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 

R

randGen - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
RandomDimension - Class in org.apache.hadoop.hive.ql.metadata
A random dimension is an abstract dimension.
RandomDimension(Class, String) - Constructor for class org.apache.hadoop.hive.ql.metadata.RandomDimension
 
range(int, int) - Method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
range(long, long) - Method in class org.apache.hadoop.hive.ql.io.orc.Reader.Options
Set the range of bytes to read
RangeBoundaryDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
RangeBoundaryDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.RangeBoundaryDef
 
RAWDATASIZE - Static variable in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
RBRACE - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
RBRACKET - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
RCFile - Class in org.apache.hadoop.hive.ql.io
RCFiles, short of Record Columnar File, are flat files consisting of binary key/value pairs, which shares much similarity with SequenceFile.
RCFile() - Constructor for class org.apache.hadoop.hive.ql.io.RCFile
 
RCFile.KeyBuffer - Class in org.apache.hadoop.hive.ql.io
KeyBuffer is the key of each record in RCFile.
RCFile.KeyBuffer() - Constructor for class org.apache.hadoop.hive.ql.io.RCFile.KeyBuffer
Deprecated. 
RCFile.Reader - Class in org.apache.hadoop.hive.ql.io
Read KeyBuffer/ValueBuffer pairs from a RCFile.
RCFile.Reader(FileSystem, Path, Configuration) - Constructor for class org.apache.hadoop.hive.ql.io.RCFile.Reader
Create a new RCFile reader.
RCFile.Reader(FileSystem, Path, int, Configuration, long, long) - Constructor for class org.apache.hadoop.hive.ql.io.RCFile.Reader
Create a new RCFile reader.
RCFile.ValueBuffer - Class in org.apache.hadoop.hive.ql.io
ValueBuffer is the value of each record in RCFile.
RCFile.ValueBuffer() - Constructor for class org.apache.hadoop.hive.ql.io.RCFile.ValueBuffer
Deprecated. 
RCFile.ValueBuffer(RCFile.KeyBuffer) - Constructor for class org.apache.hadoop.hive.ql.io.RCFile.ValueBuffer
Deprecated. 
RCFile.ValueBuffer(RCFile.KeyBuffer, boolean[]) - Constructor for class org.apache.hadoop.hive.ql.io.RCFile.ValueBuffer
Deprecated. 
RCFile.ValueBuffer(RCFile.KeyBuffer, int, boolean[], CompressionCodec) - Constructor for class org.apache.hadoop.hive.ql.io.RCFile.ValueBuffer
Deprecated. 
RCFile.ValueBuffer(RCFile.KeyBuffer, int, boolean[], CompressionCodec, boolean) - Constructor for class org.apache.hadoop.hive.ql.io.RCFile.ValueBuffer
 
RCFile.Writer - Class in org.apache.hadoop.hive.ql.io
Write KeyBuffer/ValueBuffer pairs to a RCFile.
RCFile.Writer(FileSystem, Configuration, Path) - Constructor for class org.apache.hadoop.hive.ql.io.RCFile.Writer
Constructs a RCFile Writer.
RCFile.Writer(FileSystem, Configuration, Path, Progressable, CompressionCodec) - Constructor for class org.apache.hadoop.hive.ql.io.RCFile.Writer
Constructs a RCFile Writer.
RCFile.Writer(FileSystem, Configuration, Path, Progressable, SequenceFile.Metadata, CompressionCodec) - Constructor for class org.apache.hadoop.hive.ql.io.RCFile.Writer
Constructs a RCFile Writer.
RCFile.Writer(FileSystem, Configuration, Path, int, short, long, Progressable, SequenceFile.Metadata, CompressionCodec) - Constructor for class org.apache.hadoop.hive.ql.io.RCFile.Writer
Constructs a RCFile Writer.
RCFileBlockMergeInputFormat - Class in org.apache.hadoop.hive.ql.io.rcfile.merge
 
RCFileBlockMergeInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeInputFormat
 
RCFileBlockMergeOutputFormat - Class in org.apache.hadoop.hive.ql.io.rcfile.merge
 
RCFileBlockMergeOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeOutputFormat
 
RCFileBlockMergeRecordReader - Class in org.apache.hadoop.hive.ql.io.rcfile.merge
 
RCFileBlockMergeRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeRecordReader
 
RCFileInputFormat<K extends org.apache.hadoop.io.LongWritable,V extends BytesRefArrayWritable> - Class in org.apache.hadoop.hive.ql.io
RCFileInputFormat.
RCFileInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.RCFileInputFormat
 
RCFileKeyBufferWrapper - Class in org.apache.hadoop.hive.ql.io.rcfile.merge
 
RCFileKeyBufferWrapper() - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
RCFileMergeMapper - Class in org.apache.hadoop.hive.ql.io.rcfile.merge
 
RCFileMergeMapper() - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileMergeMapper
 
RCFileOutputFormat - Class in org.apache.hadoop.hive.ql.io
RCFileOutputFormat.
RCFileOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.RCFileOutputFormat
 
RCFileRecordReader<K extends org.apache.hadoop.io.LongWritable,V extends BytesRefArrayWritable> - Class in org.apache.hadoop.hive.ql.io
RCFileRecordReader.
RCFileRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
RCFileValueBufferWrapper - Class in org.apache.hadoop.hive.ql.io.rcfile.merge
 
RCFileValueBufferWrapper() - Constructor for class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileValueBufferWrapper
 
read(MapJoinObjectSerDeContext, ObjectInputStream, Writable) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
read(MapJoinObjectSerDeContext, Writable) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
read(ByteStream.Output, MapJoinKey, MapJoinObjectSerDeContext, Writable, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKey
 
read(MapJoinObjectSerDeContext, ObjectInputStream, Writable) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyObject
 
read(MapJoinObjectSerDeContext, Writable) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyObject
 
read() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
read(byte[]) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
read(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
read(byte[]) - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads bytes from the source stream into the byte array buffer.
read(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Read at most length bytes from this DataInputStream and stores them in byte array buffer starting at offset.
read() - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
read(char[], int, int) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
readBoolean() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readBoolean() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads a boolean from this stream.
readByte() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readByte() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads an 8-bit byte value from this stream.
readChar() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readChar() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
 
readColumn(DataInput, OutputStream) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
readDouble() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readDouble() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads a 64-bit double value from this stream.
ReadEntity - Class in org.apache.hadoop.hive.ql.hooks
This class encapsulates the information on the partition and tables that are read by the query.
ReadEntity() - Constructor for class org.apache.hadoop.hive.ql.hooks.ReadEntity
For serialization only.
ReadEntity(Database) - Constructor for class org.apache.hadoop.hive.ql.hooks.ReadEntity
Constructor for a database.
ReadEntity(Table) - Constructor for class org.apache.hadoop.hive.ql.hooks.ReadEntity
Constructor.
ReadEntity(Table, ReadEntity) - Constructor for class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
ReadEntity(Table, ReadEntity, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
ReadEntity(Partition) - Constructor for class org.apache.hadoop.hive.ql.hooks.ReadEntity
Constructor given a partition.
ReadEntity(Partition, ReadEntity) - Constructor for class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
ReadEntity(Partition, ReadEntity, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
ReadEntity(Path, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.ReadEntity
Constructor for a file.
Reader - Interface in org.apache.hadoop.hive.ql.io.orc
The interface for reading ORC files.
Reader.Options - Class in org.apache.hadoop.hive.ql.io.orc
Options for creating a RecordReader.
Reader.Options() - Constructor for class org.apache.hadoop.hive.ql.io.orc.Reader.Options
 
readerOptions(Configuration) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcFile
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Writable interface.
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.NullRowsInputFormat.DummyInputSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcNewSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcStruct
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BinaryWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.RCFile.KeyBuffer
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileValueBufferWrapper
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.RCFile.ValueBuffer
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.RecordIdentifier
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat.SymlinkTextInputSplit
 
readFloat() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readFloat() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads a 32-bit float value from this stream.
readFromList(List<LongWritable>) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readFromRow(ByteStream.Output, MapJoinKey, Object, List<ExprNodeEvaluator>, List<ObjectInspector>, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKey
 
readFromVector(ByteStream.Output, MapJoinKey, VectorHashKeyWrapper, VectorExpressionWriter[], VectorHashKeyWrapperBatch, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKey
 
readFromVector(VectorHashKeyWrapper, VectorExpressionWriter[], VectorHashKeyWrapperBatch) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyObject
 
readFully(byte[]) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readFully(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readFully(byte[]) - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads bytes from this stream into the byte array buffer.
readFully(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads bytes from this stream and stores them in the byte array buffer starting at the position offset.
readInt() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readInt() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads a 32-bit integer value from this stream.
readLine() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readLine() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Deprecated. Use BufferedReader
readLong() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readLong() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads a 64-bit long value from this stream.
readMetaData(FileSystem, Path) - Static method in class org.apache.hadoop.hive.ql.parse.EximUtil
 
readObject() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readProps(ASTNode, Map<String, String>) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Converts parsed key/value properties pairs into a map.
readShort() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readShort() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads a 16-bit short value from this stream.
readUnsignedByte() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readUnsignedByte() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads an unsigned 8-bit byte value from this stream and returns it as an int.
readUnsignedShort() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readUnsignedShort() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads a 16-bit unsigned short value from this stream and returns it as an int.
readUTF() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
readUTF() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads a UTF format String from this Stream.
readUTF(DataInput) - Static method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads a UTF format String from the DataInput Stream in.
ready() - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
realFile(String, Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Shamelessly cloned from GenericOptionsParser.
recommendInputName(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
Recommend name for the expression
RECORD_INTERVAL_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.io.RCFile
 
RecordIdentifier - Class in org.apache.hadoop.hive.ql.io
Gives the Record identifer information for the current record.
RecordIdentifier() - Constructor for class org.apache.hadoop.hive.ql.io.RecordIdentifier
 
RecordIdentifier(long, int, long) - Constructor for class org.apache.hadoop.hive.ql.io.RecordIdentifier
 
RecordProcessor - Class in org.apache.hadoop.hive.ql.exec.tez
Process input from tez LogicalInput and write output It has different subclasses for map and reduce processing
RecordProcessor() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.RecordProcessor
 
RecordReader - Interface in org.apache.hadoop.hive.ql.exec
RecordReader.
RecordReader - Interface in org.apache.hadoop.hive.ql.io.orc
A row-by-row iterator for ORC files.
RecordUpdater - Interface in org.apache.hadoop.hive.ql.io
API for supporting updating records.
RecordWriter - Interface in org.apache.hadoop.hive.ql.exec
RecordWriter.
reduce(Object, Iterator, OutputCollector, Reporter) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecReducer
 
REDUCE_PLAN_NAME - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
reduceDone() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
reduceDone() - Method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
reduceDone() - Method in class org.apache.hadoop.hive.ql.exec.mr.MapRedTask
 
reduceFieldNameList - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
ReduceRecordProcessor - Class in org.apache.hadoop.hive.ql.exec.tez
Process input from tez LogicalInput and write output - for a map plan Just pump the records through the query plan.
ReduceRecordProcessor() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.ReduceRecordProcessor
 
ReducerTimeStatsPerJob - Class in org.apache.hadoop.hive.ql.plan
 
ReducerTimeStatsPerJob(List<Integer>) - Constructor for class org.apache.hadoop.hive.ql.plan.ReducerTimeStatsPerJob
 
ReduceSinkDeDuplication - Class in org.apache.hadoop.hive.ql.optimizer.correlation
If two reducer sink operators share the same partition/sort columns and order, they can be merged.
ReduceSinkDeDuplication() - Constructor for class org.apache.hadoop.hive.ql.optimizer.correlation.ReduceSinkDeDuplication
 
ReduceSinkDeDuplication.AbsctractReducerReducerProc - Class in org.apache.hadoop.hive.ql.optimizer.correlation
 
ReduceSinkDeDuplication.AbsctractReducerReducerProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.correlation.ReduceSinkDeDuplication.AbsctractReducerReducerProc
 
ReduceSinkDesc - Class in org.apache.hadoop.hive.ql.plan
ReduceSinkDesc.
ReduceSinkDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
ReduceSinkDesc(ArrayList<ExprNodeDesc>, int, ArrayList<ExprNodeDesc>, ArrayList<String>, List<List<Integer>>, ArrayList<String>, int, ArrayList<ExprNodeDesc>, int, TableDesc, TableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
ReduceSinkMapJoinProc - Class in org.apache.hadoop.hive.ql.optimizer
 
ReduceSinkMapJoinProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ReduceSinkMapJoinProc
 
ReduceSinkOperator - Class in org.apache.hadoop.hive.ql.exec
Reduce Sink Operator sends output to the reduce stage.
ReduceSinkOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
reduceStarted() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
reduceStarted() - Method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
reduceStarted() - Method in class org.apache.hadoop.hive.ql.exec.mr.MapRedTask
 
ReduceTezProcessor - Class in org.apache.hadoop.hive.ql.exec.tez
Subclass that is used to indicate if this is a map or reduce process
ReduceTezProcessor() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.ReduceTezProcessor
 
ReduceWork - Class in org.apache.hadoop.hive.ql.plan
ReduceWork represents all the information used to run a reduce task on the cluster.
ReduceWork() - Constructor for class org.apache.hadoop.hive.ql.plan.ReduceWork
 
ReduceWork(String) - Constructor for class org.apache.hadoop.hive.ql.plan.ReduceWork
 
ref() - Method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
refresh() - Method in class org.apache.hadoop.hive.ql.lockmgr.DbLockManager
 
refresh() - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
refresh() - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
refresh to enable new configurations.
refresh() - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
RegexErrorHeuristic - Class in org.apache.hadoop.hive.ql.exec.errors
Simple heuristic where the query and the lines of the task log file are run through regular expressions to see if they resemble a known error condition.
RegexErrorHeuristic() - Constructor for class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
register(RelOptPlanner) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveTableScanRel
 
registerCachedInput(String) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezCacheAccess
 
registerFunctionsFromPluginJar(URL, ClassLoader) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Registers Hive functions from a plugin jar, using metadata from the jar's META-INF/class-info.xml.
registerGenericUDAF(boolean, String, GenericUDAFResolver) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerGenericUDF(boolean, String, Class<? extends GenericUDF>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerGenericUDTF(boolean, String, Class<? extends GenericUDTF>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerInputFormatChecker(Class<? extends InputFormat>, Class<? extends InputFormatChecker>) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
register an InputFormatChecker for a given InputFormat.
registerJar(String) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
registerOutputFormatSubstitute(Class<? extends OutputFormat>, Class<? extends HiveOutputFormat>) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
register a substitute.
registerTableFunction(String, Class<? extends TableFunctionResolver>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerTemporaryFunction(String, Class<?>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Registers the appropriate kind of temporary function based on a class's type.
registerTemporaryGenericUDAF(String, GenericUDAFResolver) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerTemporaryGenericUDF(String, Class<? extends GenericUDF>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerTemporaryGenericUDTF(String, Class<? extends GenericUDTF>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerTemporaryMacro(String, ExprNodeDesc, List<String>, List<TypeInfo>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Registers thae appropriate kind of temporary function based on a class's type.
registerTemporaryUDAF(String, Class<? extends UDAF>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerTemporaryUDF(String, Class<? extends UDF>, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerUDAF(boolean, String, Class<? extends UDAF>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerUDF(boolean, String, Class<? extends UDF>, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerUDF(String, Class<? extends UDF>, boolean, String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerUDF(boolean, String, Class<? extends UDF>, boolean, String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerWindowFunction(String, GenericUDAFResolver) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerWindowFunction(String, GenericUDAFResolver, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Typically a WindowFunction is the same as a UDAF.
relativeToAbsolutePath(HiveConf, String) - Static method in class org.apache.hadoop.hive.ql.parse.EximUtil
 
RELEASE_LOCKS - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
releaseAllLocks(HiveConf) - Static method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
releaseLocks(List<HiveLock>) - Method in class org.apache.hadoop.hive.ql.lockmgr.DbLockManager
 
releaseLocks(List<HiveLock>) - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
releaseLocks(List<HiveLock>, int, int) - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
releaseLocks(List<HiveLock>) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
releaseLocks(List<HiveLock>) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
RelNodeConverter - Class in org.apache.hadoop.hive.ql.optimizer.optiq.translator
 
RelNodeConverter() - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.translator.RelNodeConverter
 
RelOptHiveTable - Class in org.apache.hadoop.hive.ql.optimizer.optiq
 
RelOptHiveTable(RelOptSchema, String, RelDataType, Table, Statistics) - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.RelOptHiveTable
 
remove(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.DriverContext
 
remove(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
remove() - Method in class org.apache.hadoop.hive.ql.exec.PTFUtils.ReverseIterator
 
remove(Object, Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.AbstractParquetMapInspector
 
remove(BaseWork) - Method in class org.apache.hadoop.hive.ql.plan.TezWork
remove removes a node from the graph and removes all edges with work as start or end point.
removeChild(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
removeChildAndAdoptItsChildren(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Remove a child and add all of the child's children to the location of the child
removeChildren(int) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
removeDependentTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Task
Remove the dependent task.
removeFromChildrenTasks() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
removeFromClassPath(String[]) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
remove elements from the classpath.
removeFromRootTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
removeOperator(Operator<?>, ParseContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities
 
removeOpParseCtx(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
Remove the OpParseContext of a specific operator op
removeParent(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
removePrefixFromWarehouseConfig(String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Remove prefix from "Path -> Alias" This is required for testing.
removeTempOrDuplicateFiles(FileSystem, Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Remove all temporary files and duplicate (double-committed) files from a given directory.
removeTempOrDuplicateFiles(FileSystem, Path, DynamicPartitionCtx) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Remove all temporary files and duplicate (double-committed) files from a given directory.
removeTempOrDuplicateFiles(FileStatus[], FileSystem) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
removeUnionOperators(Configuration, GenTezProcContext, BaseWork) - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
removeVirtualColumns(Collection<String>) - Static method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
rename(FileSystem, Path, Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Rename src to dst, or in the case dst already exists, move files in src to dst.
renameOrMoveFiles(FileSystem, Path, Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Rename src to dst, or in the case dst already exists, move files in src to dst.
renamePartition(Table, Map<String, String>, Partition) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Rename a old partition to new partition
RenamePartitionDesc - Class in org.apache.hadoop.hive.ql.plan
Contains the information needed to rename a partition.
RenamePartitionDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.RenamePartitionDesc
For serialization only.
RenamePartitionDesc(String, String, Map<String, String>, Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.RenamePartitionDesc
 
renderOrigin(StringBuilder, ASTNodeOrigin) - Static method in enum org.apache.hadoop.hive.ql.ErrorMsg
 
replace(ExprNodeDesc, List<ExprNodeDesc>, List<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
 
replaceChild(Operator<? extends OperatorDesc>, Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Replace one child with another at the same position.
replaceFSwithLS(Operator<?>, String) - Static method in class org.apache.hadoop.hive.ql.optimizer.SimpleFetchOptimizer
 
replaceMapWork(String, String, MapWork, MapWork) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Replace the Map-side operator tree associated with targetAlias in target with the Map-side operator tree associated with sourceAlias in source.
replaceParent(Operator<? extends OperatorDesc>, Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Replace one parent with another at the same position.
replaceRoots(Map<Operator<?>, Operator<?>>) - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
replaceRoots(Map<Operator<?>, Operator<?>>) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
replaceRoots(Map<Operator<?>, Operator<?>>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
replaceRoots(Map<Operator<?>, Operator<?>>) - Method in class org.apache.hadoop.hive.ql.plan.UnionWork
 
replaceRootTask(Task<? extends Serializable>, List<? extends Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
replaceTaskIdFromFilename(String, int) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Replace the task id from the filename.
replaceTaskIdFromFilename(String, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
reporter(Reporter) - Method in class org.apache.hadoop.hive.ql.io.AcidInputFormat.Options
Supply the reporter.
reporter(Reporter) - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
Provide the MapReduce reporter.
RequiredPrivileges - Class in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
Captures privilege sets, and can be used to compare required and available privileges to find missing privileges (if any).
RequiredPrivileges() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.RequiredPrivileges
 
requireLock() - Method in class org.apache.hadoop.hive.ql.exec.DDLTask
 
requireLock() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
requireLock() - Method in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
requireLock() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
requireLock() - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.BlockMergeTask
 
requireLock() - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanTask
 
requireLock() - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateTask
 
reset() - Method in class org.apache.hadoop.hive.ql.exec.DummyStoreOperator
 
reset(List) - Method in class org.apache.hadoop.hive.ql.exec.ListSinkOperator
 
reset() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
reset() - Method in interface org.apache.hadoop.hive.ql.exec.PTFPartition.PTFPartitionIterator
 
reset() - Method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
reset() - Method in class org.apache.hadoop.hive.ql.exec.vector.ColumnVector
Resets the column to default state - fills the isNull array with false - sets noNulls to true - sets isRepeating to false
reset() - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorAggregateExpression.AggregationBuffer
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorAggregateExpression
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFAvgDecimal
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCount
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCountStar
 
reset(VectorAggregateExpression.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFSumDecimal
 
reset() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferRow
Resets the aggregation buffers for reuse
reset() - Method in interface org.apache.hadoop.hive.ql.exec.vector.VectorColumnAssign
 
reset() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
Resets the row batch to default state - sets selectedInUse to false - sets size to 0 - sets endOfFile to false - resets each column
reset(byte[], int) - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Resets the data that the buffer reads.
reset(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Resets the data that the buffer reads.
reset() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataOutputBuffer
Resets the buffer to empty.
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Reset the aggregation.
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEWAHBitmap.GenericUDAFEWAHBitmapEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFFirstValue.GenericUDAFFirstValueEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLastValue.GenericUDAFLastValueEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMkCollectionEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFNTile.GenericUDAFNTileEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank.GenericUDAFRankEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRowNumber.GenericUDAFRowNumberEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumDouble
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumHiveDecimal
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumLong
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance.GenericUDAFVarianceEvaluator
 
reset() - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Resets an n-gram estimator object to its initial state.
reset() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
Resets a distinctValueEstimator object to its original state.
reset() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Resets a histogram object to its initial state.
reset() - Method in class org.apache.hadoop.hive.ql.udf.generic.UDTFCollector
 
reset() - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
resetBuffer() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Resets the values which determine if there are more rows in the buffer This can be used after one calls seek or sync, if one called next before that.
resetBuffer() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
resetBuffer() - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
resetFetch() - Method in class org.apache.hadoop.hive.ql.Driver
 
resetId() - Static method in class org.apache.hadoop.hive.ql.exec.Operator
 
resetId() - Static method in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
resetOrder() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
ResetProcessor - Class in org.apache.hadoop.hive.ql.processors
 
ResetProcessor() - Constructor for class org.apache.hadoop.hive.ql.processors.ResetProcessor
 
resetRow() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
Reset the execution context for each new row.
resetSequenceNumber() - Method in class org.apache.hadoop.hive.ql.parse.GenTezUtils
 
resetSortingValues() - Method in class org.apache.hadoop.hive.ql.io.IOContext
The thread local IOContext is static, we may need to restart the search if, for instance, multiple files are being searched as part of a CombinedHiveRecordReader
resetStats() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
resetStream() - Method in class org.apache.hadoop.hive.ql.Context
 
resetToIndex(int) - Method in interface org.apache.hadoop.hive.ql.exec.PTFPartition.PTFPartitionIterator
 
residualPredicate - Variable in class org.apache.hadoop.hive.ql.metadata.HiveStoragePredicateHandler.DecomposedPredicate
Portion of predicate to be post-evaluated by Hive for any rows which are returned by storage handler.
resize(Object, int) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveArrayInspector
 
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingInferenceOptimizer
 
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.CommonJoinResolver
 
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.CrossProductCheck
 
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.IndexWhereResolver
 
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver
 
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MetadataOnlyOptimizer
 
resolve(PhysicalContext) - Method in interface org.apache.hadoop.hive.ql.optimizer.physical.PhysicalPlanResolver
All physical plan resolvers have to implement this entry method.
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SamplingOptimizer
 
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinResolver
 
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SortMergeJoinResolver
 
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.StageIDsRearranger
 
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.Vectorizer
 
resolveConcatenateMerge(HiveConf) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
alter table ...
resolveDynamicPartitionStoredAsSubDirsMerge(HiveConf, Path, TableDesc, ArrayList<String>, PartitionDesc) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
resolveDynamicPartitionStoredAsSubDirsMerge(HiveConf, Path, TableDesc, ArrayList<String>, PartitionDesc) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
restoreOriginalTracker() - Method in class org.apache.hadoop.hive.ql.Context
 
restoreSession(Driver.QueryState) - Method in class org.apache.hadoop.hive.ql.Driver
 
ResultVector - Variable in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.NodeInfoWrapper
 
retrieve(InspectableObject) - Method in class org.apache.hadoop.hive.ql.exec.CollectOperator
 
retrieve(String) - Method in class org.apache.hadoop.hive.ql.exec.mr.ObjectCache
 
retrieve(String) - Method in interface org.apache.hadoop.hive.ql.exec.ObjectCache
Retrieve object from cache.
retrieve(String) - Method in class org.apache.hadoop.hive.ql.exec.tez.ObjectCache
 
returnCompressor(Compressor) - Static method in class org.apache.hadoop.hive.ql.io.CodecPool
Return the Compressor to the pool.
returnDecompressor(Decompressor) - Static method in class org.apache.hadoop.hive.ql.io.CodecPool
Return the Decompressor to the pool.
returnSession(TezSessionState) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
reverseLookup(String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
RevokeDesc - Class in org.apache.hadoop.hive.ql.plan
 
RevokeDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
RevokeDesc(List<PrivilegeDesc>, List<PrincipalDesc>, PrivilegeObjectDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
RevokePrivAuthUtils - Class in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
 
RevokePrivAuthUtils() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.RevokePrivAuthUtils
 
revokePrivileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
revokePrivileges(List<HivePrincipal>, List<HivePrivilege>, HivePrivilegeObject, HivePrincipal, boolean) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessController
 
revokePrivileges(List<HivePrincipal>, List<HivePrivilege>, HivePrivilegeObject, HivePrincipal, boolean) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
Revoke privileges for principals on the object
revokePrivileges(List<HivePrincipal>, List<HivePrivilege>, HivePrivilegeObject, HivePrincipal, boolean) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
revokePrivileges(List<HivePrincipal>, List<HivePrivilege>, HivePrivilegeObject, HivePrincipal, boolean) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
revokeRole(String, String, PrincipalType) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
revokeRole(List<HivePrincipal>, List<String>, boolean, HivePrincipal) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessController
 
revokeRole(List<HivePrincipal>, List<String>, boolean, HivePrincipal) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
Revoke roles in given roles list to principals in given hivePrincipals list
revokeRole(List<HivePrincipal>, List<String>, boolean, HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
revokeRole(List<HivePrincipal>, List<String>, boolean, HivePrincipal) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
rework(HiveConf, MapredWork) - Method in interface org.apache.hadoop.hive.ql.io.ReworkMapredInputFormat
 
rework(HiveConf, MapredWork) - Method in class org.apache.hadoop.hive.ql.io.SymbolicInputFormat
 
ReworkMapredInputFormat - Interface in org.apache.hadoop.hive.ql.io
 
reworkMapRedWork(Task<? extends Serializable>, boolean, HiveConf) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
The check here is kind of not clean.
RewriteCanApplyCtx - Class in org.apache.hadoop.hive.ql.optimizer.index
RewriteCanApplyCtx class stores the context for the RewriteCanApplyProcFactory to determine if any index can be used and if the input query meets all the criteria for rewrite optimization.
RewriteCanApplyProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.index
Factory of methods used by RewriteGBUsingIndex to determine if the rewrite optimization can be applied to the input query.
rewriteCTEToSubq(String, String, QBExpr) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
RewriteGBUsingIndex - Class in org.apache.hadoop.hive.ql.optimizer.index
RewriteGBUsingIndex is implemented as one of the Rule-based Optimizations.
RewriteGBUsingIndex() - Constructor for class org.apache.hadoop.hive.ql.optimizer.index.RewriteGBUsingIndex
 
RewriteParseContextGenerator - Class in org.apache.hadoop.hive.ql.optimizer.index
RewriteParseContextGenerator is a class that offers methods to generate operator tree for input queries.
RewriteQueryUsingAggregateIndex - Class in org.apache.hadoop.hive.ql.optimizer.index
This class defines a procedure factory used to rewrite the operator plan Each method replaces the necessary base table data structures with the index table data structures for each operator.
RewriteQueryUsingAggregateIndexCtx - Class in org.apache.hadoop.hive.ql.optimizer.index
RewriteQueryUsingAggregateIndexCtx class stores the context for the RewriteQueryUsingAggregateIndex used to rewrite operator plan with index table instead of base table.
rewriteViewToSubq(String, String, QBExpr) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
RexNodeConverter - Class in org.apache.hadoop.hive.ql.optimizer.optiq.translator
 
RexNodeConverter(RelOptCluster, RelDataType, ImmutableMap<String, Integer>, int, boolean) - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.translator.RexNodeConverter
 
RIGHT - Static variable in class org.apache.hadoop.hive.ql.optimizer.optiq.rules.HivePushJoinThroughJoinRule
 
RIGHT_OUTER_JOIN - Static variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
RIGHT_PROJECT - Static variable in class org.apache.hadoop.hive.ql.optimizer.optiq.rules.HivePullUpProjectsAboveJoinRule
 
RoleDDLDesc - Class in org.apache.hadoop.hive.ql.plan
 
RoleDDLDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
RoleDDLDesc(String, RoleDDLDesc.RoleOperation) - Constructor for class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
RoleDDLDesc(String, PrincipalType, RoleDDLDesc.RoleOperation, String) - Constructor for class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
RoleDDLDesc.RoleOperation - Enum in org.apache.hadoop.hive.ql.plan
 
rollbackTxn() - Method in class org.apache.hadoop.hive.ql.lockmgr.DbTxnManager
 
rollbackTxn() - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveTxnManager
Abort the current transaction.
rootOperators - Variable in class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 
rootTasks - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
rootToWorkMap - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
round(int, Decimal128, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
round(double) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
round(double, int) - Static method in class org.apache.hadoop.hive.ql.udf.generic.RoundUtils
Rounding a double is approximate, as the double value itself is approximate.
round(long, int) - Static method in class org.apache.hadoop.hive.ql.udf.generic.RoundUtils
 
round(HiveDecimal, int) - Static method in class org.apache.hadoop.hive.ql.udf.generic.RoundUtils
 
round(int) - Static method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
 
RoundUtils - Class in org.apache.hadoop.hive.ql.udf.generic
Utility class for generic round UDF.
RoundWithNumDigitsDoubleToDouble - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
RoundWithNumDigitsDoubleToDouble(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.RoundWithNumDigitsDoubleToDouble
 
RoundWithNumDigitsDoubleToDouble() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.RoundWithNumDigitsDoubleToDouble
 
routeDataMovementEventToDestination(DataMovementEvent, int, int, Map<Integer, List<Integer>>) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionEdge
 
routeInputErrorEventToSource(InputReadErrorEvent, int) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionEdge
 
routeInputSourceTaskFailedEventToDestination(int, int, Map<Integer, List<Integer>>) - Method in class org.apache.hadoop.hive.ql.exec.tez.CustomPartitionEdge
 
ROW_INDEX_STRIDE - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcFile
Deprecated. 
RowContainer<ROW extends List<Object>> - Class in org.apache.hadoop.hive.ql.exec.persistence
Simple persistent container for rows.
RowContainer(Configuration, Reporter) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
RowContainer(int, Configuration, Reporter) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
rowCount() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer
 
rowCount() - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
rowCount() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
Get the number of elements in the RowContainer.
rowCount() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
Get the number of elements in the RowContainer.
rowCountMap - Variable in class org.apache.hadoop.hive.ql.history.HiveHistory.QueryInfo
 
rowIndexStride(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
Set the distance between entries in the row index.
rowIter() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer
 
rowIter() - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
rowIter() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
rowIter() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
ROWOFFSET - Static variable in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
RowResolver - Class in org.apache.hadoop.hive.ql.parse
Implementation of the Row Resolver.
RowResolver() - Constructor for class org.apache.hadoop.hive.ql.parse.RowResolver
 
rows() - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Create a RecordReader that reads everything with the default options.
rows(boolean[]) - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Create a RecordReader that will scan the entire file.
rows(long, long, boolean[]) - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Create a RecordReader that will start reading at the first stripe after offset up to the stripe that starts at offset + length.
rows(long, long, boolean[], SearchArgument, String[]) - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Create a RecordReader that will read a section of a file.
RowSchema - Class in org.apache.hadoop.hive.ql.exec
RowSchema Implementation.
RowSchema() - Constructor for class org.apache.hadoop.hive.ql.exec.RowSchema
 
RowSchema(RowSchema) - Constructor for class org.apache.hadoop.hive.ql.exec.RowSchema
 
RowSchema(ArrayList<ColumnInfo>) - Constructor for class org.apache.hadoop.hive.ql.exec.RowSchema
 
rowsOptions(Reader.Options) - Method in interface org.apache.hadoop.hive.ql.io.orc.Reader
Create a RecordReader that uses the options given.
Rule - Interface in org.apache.hadoop.hive.ql.lib
Rule interface for Operators Used in operator dispatching to dispatch process/visitor functions for operators.
RuleExactMatch - Class in org.apache.hadoop.hive.ql.lib
Implentation of the Rule interface for Nodes Used in Node dispatching to dispatch process/visitor functions for Nodes.
RuleExactMatch(String, String) - Constructor for class org.apache.hadoop.hive.ql.lib.RuleExactMatch
The rule specified as operator names separated by % symbols, the left side represents the bottom of the stack.
RuleRegExp - Class in org.apache.hadoop.hive.ql.lib
Rule interface for Nodes Used in Node dispatching to dispatch process/visitor functions for Nodes.
RuleRegExp(String, String) - Constructor for class org.apache.hadoop.hive.ql.lib.RuleRegExp
The rule specified by the regular expression.
run(String) - Method in class org.apache.hadoop.hive.ql.Driver
 
run() - Method in class org.apache.hadoop.hive.ql.Driver
 
run(String, boolean) - Method in class org.apache.hadoop.hive.ql.Driver
 
run() - Method in class org.apache.hadoop.hive.ql.exec.mr.JobDebugger
 
run() - Method in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
run(Map<String, LogicalInput>, Map<String, LogicalOutput>) - Method in class org.apache.hadoop.hive.ql.exec.tez.HivePreWarmProcessor
 
run(Map<String, LogicalInput>, Map<String, LogicalOutput>) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezProcessor
 
run(PreparedStatement) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.SQLCommand
 
run() - Method in class org.apache.hadoop.hive.ql.exec.Utilities.StreamPrinter
 
run(HookContext) - Method in class org.apache.hadoop.hive.ql.hooks.ATSHook
 
run(HookContext) - Method in class org.apache.hadoop.hive.ql.hooks.EnforceReadOnlyTables
 
run(SessionState, Set<ReadEntity>, Set<WriteEntity>, UserGroupInformation) - Method in class org.apache.hadoop.hive.ql.hooks.EnforceReadOnlyTables
 
run(HookContext) - Method in interface org.apache.hadoop.hive.ql.hooks.ExecuteWithHookContext
 
run(SessionState, Set<ReadEntity>, Set<WriteEntity>, LineageInfo, UserGroupInformation) - Method in interface org.apache.hadoop.hive.ql.hooks.PostExecute
Deprecated. 
run(HookContext) - Method in class org.apache.hadoop.hive.ql.hooks.PostExecutePrinter
 
run(SessionState, Set<ReadEntity>, Set<WriteEntity>, LineageInfo, UserGroupInformation) - Method in class org.apache.hadoop.hive.ql.hooks.PostExecutePrinter
 
run(SessionState, Set<ReadEntity>, Set<WriteEntity>, UserGroupInformation) - Method in interface org.apache.hadoop.hive.ql.hooks.PreExecute
Deprecated. 
run(HookContext) - Method in class org.apache.hadoop.hive.ql.hooks.PreExecutePrinter
 
run(SessionState, Set<ReadEntity>, Set<WriteEntity>, UserGroupInformation) - Method in class org.apache.hadoop.hive.ql.hooks.PreExecutePrinter
 
run(SessionState, Set<ReadEntity>, Set<WriteEntity>, UserGroupInformation) - Method in class org.apache.hadoop.hive.ql.hooks.UpdateInputAccessTimeHook.PreExec
 
run(String) - Method in class org.apache.hadoop.hive.ql.processors.AddResourceProcessor
 
run(String) - Method in interface org.apache.hadoop.hive.ql.processors.CommandProcessor
 
run(String) - Method in class org.apache.hadoop.hive.ql.processors.CompileProcessor
User supplies dynamic code in this format: COMPILE ` some code here ` AS groovy NAMED something.groovy; CompileProcessor will compile and package this code into a jar.
run(String) - Method in class org.apache.hadoop.hive.ql.processors.DeleteResourceProcessor
 
run(String) - Method in class org.apache.hadoop.hive.ql.processors.DfsProcessor
 
run(String) - Method in class org.apache.hadoop.hive.ql.processors.ResetProcessor
 
run(String) - Method in class org.apache.hadoop.hive.ql.processors.SetProcessor
 
run(HookContext) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.DisallowTransformHook
 
run(Map<String, Double>, String) - Method in interface org.apache.hadoop.hive.ql.stats.ClientStatsPublisher
 
run() - Method in class org.apache.hadoop.hive.ql.txn.compactor.Cleaner
 
run() - Method in class org.apache.hadoop.hive.ql.txn.compactor.Initiator
 
run() - Method in class org.apache.hadoop.hive.ql.txn.compactor.Worker
 
RUN_TASKS - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
runningJobs - Static variable in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
A list of the currently running jobs spawned in this Hive instance that is used to kill all running jobs in the event of an unexpected shutdown - i.e., the JVM shuts down while there are still jobs running.
runSequential() - Method in class org.apache.hadoop.hive.ql.exec.TaskRunner
Launches a task, and sets its exit value in the result variable.
runtimeSerializationKryo - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 

S

Sample - Class in org.apache.hadoop.hive.ql.metadata
A sample defines a subset of data based on sampling on a given dimension.
Sample(int, int, Dimension) - Constructor for class org.apache.hadoop.hive.ql.metadata.Sample
 
SamplePruner - Class in org.apache.hadoop.hive.ql.optimizer
The transformation step that does sample pruning.
SamplePruner() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SamplePruner
 
SamplePruner.AddPathReturnStatus - Class in org.apache.hadoop.hive.ql.optimizer
Class used for return value of addPath()
SamplePruner.AddPathReturnStatus(boolean, boolean, long) - Constructor for class org.apache.hadoop.hive.ql.optimizer.SamplePruner.AddPathReturnStatus
 
SamplePruner.DefaultPPR - Class in org.apache.hadoop.hive.ql.optimizer
DefaultPPR default processor which does nothing.
SamplePruner.DefaultPPR() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SamplePruner.DefaultPPR
 
SamplePruner.FilterPPR - Class in org.apache.hadoop.hive.ql.optimizer
FilterPPR filter processor.
SamplePruner.FilterPPR() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SamplePruner.FilterPPR
 
SamplePruner.LimitPruneRetStatus - Enum in org.apache.hadoop.hive.ql.optimizer
 
SamplePruner.SamplePrunerCtx - Class in org.apache.hadoop.hive.ql.optimizer
SamplePrunerCtx.
SamplePruner.SamplePrunerCtx(HashMap<TableScanOperator, FilterDesc.sampleDesc>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.SamplePruner.SamplePrunerCtx
 
SAMPLING_ON_PREV_MR - Static variable in class org.apache.hadoop.hive.ql.plan.MapWork
 
SAMPLING_ON_START - Static variable in class org.apache.hadoop.hive.ql.plan.MapWork
 
SamplingOptimizer - Class in org.apache.hadoop.hive.ql.optimizer.physical
Mark final MapredWork for ORDER BY to use sampling and set number of reduce task as -1
SamplingOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.SamplingOptimizer
 
saveSession(Driver.QueryState) - Method in class org.apache.hadoop.hive.ql.Driver
 
scale - Variable in class org.apache.hadoop.hive.ql.exec.vector.DecimalColumnVector
 
SchemaAwareCompressionInputStream - Class in org.apache.hadoop.hive.ql.io
SchemaAwareCompressionInputStream adds the ability to inform the compression stream what column is being read.
SchemaAwareCompressionOutputStream - Class in org.apache.hadoop.hive.ql.io
SchemaAwareCompressionOutputStream adds the ability to inform the comression stream the current column being compressed.
schemaCompare(List<FieldSchema>, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.parse.EximUtil
Compares the schemas - names, types and order, but ignoring comments
SchemaDesc - Class in org.apache.hadoop.hive.ql.plan
SchemaDesc.
SchemaDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.SchemaDesc
 
SchemaDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.SchemaDesc
 
ScriptDesc - Class in org.apache.hadoop.hive.ql.plan
ScriptDesc.
ScriptDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
ScriptDesc(String, TableDesc, Class<? extends RecordWriter>, TableDesc, Class<? extends RecordReader>, Class<? extends RecordReader>, TableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
ScriptErrorHeuristic - Class in org.apache.hadoop.hive.ql.exec.errors
Detects when a query has failed because a user's script that was specified in transform returns a non-zero error code.
ScriptErrorHeuristic() - Constructor for class org.apache.hadoop.hive.ql.exec.errors.ScriptErrorHeuristic
 
ScriptOperator - Class in org.apache.hadoop.hive.ql.exec
ScriptOperator.
ScriptOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
ScriptOperator.Counter - Enum in org.apache.hadoop.hive.ql.exec
Counter.
ScriptOperator.PathFinder - Class in org.apache.hadoop.hive.ql.exec
Maps a relative pathname to an absolute pathname using the PATH enviroment.
ScriptOperator.PathFinder(String) - Constructor for class org.apache.hadoop.hive.ql.exec.ScriptOperator.PathFinder
Construct a PathFinder object using the path from the specified system environment variable.
searchArgument(SearchArgument, String[]) - Method in class org.apache.hadoop.hive.ql.io.orc.Reader.Options
Set search argument for predicate push down.
SearchArgument - Interface in org.apache.hadoop.hive.ql.io.sarg
Primary interface for SearchArgument, which are the subset of predicates that can be pushed down to the RecordReader.
SearchArgument.Builder - Interface in org.apache.hadoop.hive.ql.io.sarg
A builder object for contexts outside of Hive where it isn't easy to get a ExprNodeDesc.
SearchArgument.Factory - Class in org.apache.hadoop.hive.ql.io.sarg
A factory for creating SearchArguments.
SearchArgument.Factory() - Constructor for class org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Factory
 
SearchArgument.TruthValue - Enum in org.apache.hadoop.hive.ql.io.sarg
The potential result sets of logical operations.
SecureCmdDoAs - Class in org.apache.hadoop.hive.ql.exec
SecureCmdDoAs - Helper class for setting parameters and env necessary for being able to run child jvm as intended user.
SecureCmdDoAs(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.exec.SecureCmdDoAs
 
seek(long) - Method in class org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer.PTFSequenceFileRecordReader
 
seek(long) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Set the current byte position in the input file.
seekToRow(long) - Method in interface org.apache.hadoop.hive.ql.io.orc.RecordReader
Seek to a particular row number.
SELECT - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
SELECT_TAG - Static variable in class org.apache.hadoop.hive.ql.exec.LateralViewJoinOperator
 
SelectColumnIsFalse - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This expression selects a row if the given boolean column is false.
SelectColumnIsFalse(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsFalse
 
SelectColumnIsFalse() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsFalse
 
SelectColumnIsNotNull - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This expression selects a row if the given column is null.
SelectColumnIsNotNull(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNotNull
 
SelectColumnIsNotNull() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNotNull
 
SelectColumnIsNull - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This expression selects a row if the given column is null.
SelectColumnIsNull(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNull
 
SelectColumnIsNull() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNull
 
SelectColumnIsTrue - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This expression selects a row if the given boolean column is true.
SelectColumnIsTrue(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsTrue
 
SelectColumnIsTrue() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsTrue
 
SelectDesc - Class in org.apache.hadoop.hive.ql.plan
SelectDesc.
SelectDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.SelectDesc
 
SelectDesc(boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.SelectDesc
 
SelectDesc(List<ExprNodeDesc>, List<String>) - Constructor for class org.apache.hadoop.hive.ql.plan.SelectDesc
 
SelectDesc(List<ExprNodeDesc>, List<String>, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.SelectDesc
 
SelectDesc(List<ExprNodeDesc>, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.SelectDesc
 
selected - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
selectedInUse - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
SelectOperator - Class in org.apache.hadoop.hive.ql.exec
Select operator implementation.
SelectOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.SelectOperator
 
SemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
Implementation of the semantic analyzer.
SemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
SemanticAnalyzerFactory - Class in org.apache.hadoop.hive.ql.parse
SemanticAnalyzerFactory.
SemanticException - Exception in org.apache.hadoop.hive.ql.parse
Exception from SemanticAnalyzer.
SemanticException() - Constructor for exception org.apache.hadoop.hive.ql.parse.SemanticException
 
SemanticException(String) - Constructor for exception org.apache.hadoop.hive.ql.parse.SemanticException
 
SemanticException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.parse.SemanticException
 
SemanticException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.ql.parse.SemanticException
 
SemanticException(ErrorMsg, String...) - Constructor for exception org.apache.hadoop.hive.ql.parse.SemanticException
 
SequenceFileInputFormatChecker - Class in org.apache.hadoop.hive.ql.io
SequenceFileInputFormatChecker.
SequenceFileInputFormatChecker() - Constructor for class org.apache.hadoop.hive.ql.io.SequenceFileInputFormatChecker
 
SerializationContextImplKey - Static variable in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
The JobConf key of the SerializationContext to use.
SerializationImplKey - Static variable in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat
The JobConf keys for the Serialization implementation.
SerializationSubclassKey - Static variable in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
The JobConf keys for the Class that is being deserialized.
serialize(OutputStream, Object) - Static method in class org.apache.hadoop.hive.ql.exec.PTFUtils
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedColumnarSerDe
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSerde
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.io.orc.VectorizedOrcSerde
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe
 
serialize() - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
In preparation for a Hive merge() call, serializes the current n-gram estimator object into an ArrayList of Text objects.
serialize() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator
 
serialize() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
In preparation for a Hive merge() call, serializes the current histogram object into an ArrayList of DoubleWritable objects.
SERIALIZE_PLAN - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
serializeDeltas(List<AcidUtils.ParsedDelta>) - Static method in class org.apache.hadoop.hive.ql.io.AcidUtils
Convert the list of deltas into an equivalent list of begin/end transaction id pairs.
serializeExpression(ExprNodeGenericFuncDesc) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
serializeExpressionToKryo(ExprNodeGenericFuncDesc) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Serializes expression via Kryo.
serializePlan(Object, OutputStream, Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Serializes the plan.
serializeVector(VectorizedRowBatch, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedColumnarSerDe
Serialize a vectorized row batch
serializeVector(VectorizedRowBatch, ObjectInspector) - Method in interface org.apache.hadoop.hive.ql.exec.vector.VectorizedSerde
 
serializeVector(VectorizedRowBatch, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSerde
 
sessionId - Variable in class org.apache.hadoop.hive.ql.history.HiveHistory.SessionInfo
 
SessionState - Class in org.apache.hadoop.hive.ql.session
SessionState encapsulates common data associated with a session.
SessionState(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.session.SessionState
 
SessionState(HiveConf, String) - Constructor for class org.apache.hadoop.hive.ql.session.SessionState
 
SessionState.AuthorizationMode - Enum in org.apache.hadoop.hive.ql.session
 
SessionState.LogHelper - Class in org.apache.hadoop.hive.ql.session
This class provides helper routines to emit informational and error messages to the user and log4j files while obeying the current session's verbosity levels.
SessionState.LogHelper(Log) - Constructor for class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
SessionState.LogHelper(Log, boolean) - Constructor for class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
SessionState.ResourceHook - Interface in org.apache.hadoop.hive.ql.session
ResourceHook.
SessionState.ResourceType - Enum in org.apache.hadoop.hive.ql.session
ResourceType.
SessionStateConfigUserAuthenticator - Class in org.apache.hadoop.hive.ql.security
Authenticator to be used for testing and debugging.
SessionStateConfigUserAuthenticator() - Constructor for class org.apache.hadoop.hive.ql.security.SessionStateConfigUserAuthenticator
 
SessionStateUserAuthenticator - Class in org.apache.hadoop.hive.ql.security
Authenticator that returns the userName set in SessionState.
SessionStateUserAuthenticator() - Constructor for class org.apache.hadoop.hive.ql.security.SessionStateUserAuthenticator
 
set(int) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
 
set(int, Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
set(Object, int, Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveArrayInspector
 
set(Object, byte) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetByteInspector
 
set(Object, short) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetShortInspector
 
set(Object, Text) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetStringInspector
 
set(Object, String) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.primitive.ParquetStringInspector
 
set(BigDecimal) - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
set(BigDecimalWritable) - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
set(byte[], int) - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
set(RecordIdentifier) - Method in class org.apache.hadoop.hive.ql.io.RecordIdentifier
Set this object to match the given object.
set(Hive) - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
 
set(String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
SET_COLUMN_NAME - Static variable in class org.apache.hadoop.hive.ql.processors.SetProcessor
 
setAbort(boolean) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapper
 
setAddedResource(boolean) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setAddPartitionDesc(AddPartitionDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setAfterCol(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setAggFuncCnt(int) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setAggFuncColList(Set<String>) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setAggFuncColsFetchException(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setAggFuncIsNotCount(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setAggFunction(String) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setAggKey(String) - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanWork
 
setAggKey(String) - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
setAggregationExprsForClause(String, LinkedHashMap<String, ASTNode>) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setAggregators(VectorAggregateExpression[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
setAggregators(ArrayList<AggregationDesc>) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setAggrExprNode(ExprNodeColumnDesc) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
setAlias(String) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setAlias(String) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Store the alias this operator is working on behalf of.
setAlias(String) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.TableAliasInfo
 
setAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
setAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
setAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowExpressionSpec
 
setAlias(String) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFInputDef
 
setAlias(String) - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowExpressionDef
 
setAlias(String) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setAliasBucketBaseFileNameMapping(Map<String, Map<String, List<String>>>) - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
setAliasBucketFileNameMapping(Map<String, Map<String, List<String>>>) - Method in interface org.apache.hadoop.hive.ql.exec.BucketMatcher
 
setAliasBucketFileNameMapping(Map<String, Map<String, List<String>>>) - Method in class org.apache.hadoop.hive.ql.exec.DefaultBucketMatcher
 
setAliasBucketFileNameMapping(Map<String, Map<String, List<String>>>) - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
setAliasBucketFileNameMapping(Map<String, Map<String, List<String>>>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setAliasToFetchWork(LinkedHashMap<String, FetchWork>) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
setAliasToKnownSize(HashMap<String, Long>) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
setAliasToOpInfo(Map<String, Operator<? extends OperatorDesc>>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setAliasToPartnInfo(LinkedHashMap<String, PartitionDesc>) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setAliasToSink(Map<String, DummyStoreOperator>) - Method in class org.apache.hadoop.hive.ql.plan.SMBJoinDesc
 
setAliasToWdwExpr(HashMap<String, WindowingSpec.WindowExpressionSpec>) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec
 
setAliasToWork(LinkedHashMap<String, Operator<? extends OperatorDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
setAliasToWork(LinkedHashMap<String, Operator<? extends OperatorDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setAllInputsInSameReducer(boolean) - Method in class org.apache.hadoop.hive.ql.plan.UnionDesc
 
setAllowStatefulFunctions(boolean) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
setAlterDatabaseDesc(AlterDatabaseDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setAlterIndexDesc(AlterIndexDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setAlterTableAlterPartDesc(AlterTableAlterPartDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setAlterTableExchangePartition(AlterTableExchangePartition) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setAlterTblDesc(AlterTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setAlterTblSimpleDesc(AlterTableSimpleDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setAlterType(AlterDatabaseDesc.ALTER_DB_TYPES) - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
setAmt(int) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.BoundarySpec
 
setAmt(int) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.CurrentRowSpec
 
setAmt(int) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.RangeBoundarySpec
 
setAmt(int) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.ValueBoundarySpec
 
setAmt(int) - Method in class org.apache.hadoop.hive.ql.plan.ptf.RangeBoundaryDef
 
setAmt(int) - Method in class org.apache.hadoop.hive.ql.plan.ptf.ValueBoundaryDef
 
setAmt(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator
 
setAmt(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
setAnalyzeRewrite(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setAndExprStats(Statistics) - Method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.AnnotateStatsProcCtx
 
setAppendTaskType(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setArg(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLogWithBaseDoubleToDouble
 
setArg(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLogWithBaseLongToDouble
 
setArg(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerDoubleToDouble
 
setArg(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerLongToDouble
 
setArg(double) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.ISetDoubleArg
 
setArg(long) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.ISetLongArg
 
setArg(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.PosModDoubleToDouble
 
setArg(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.PosModLongToLong
 
setArg(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.RoundWithNumDigitsDoubleToDouble
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringColumn
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringScalar
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringColumn
 
setArg1Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringScalar
 
setArg2Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringColumn
 
setArg2Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringScalar
 
setArg2Scalar(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringColumn
 
setArg2Scalar(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringScalar
 
setArg3Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringColumn
 
setArg3Column(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringColumn
 
setArg3Scalar(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringScalar
 
setArg3Scalar(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringScalar
 
setArgDescs(VectorUDFArgDesc[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
setArgs(List<ASTNode>) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
setArgs(ArrayList<ASTNode>) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFunctionSpec
 
setArgs(List<PTFExpressionDef>) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
setArgs(List<PTFExpressionDef>) - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
setArgumentType(int, VectorExpressionDescriptor.ArgumentType) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Builder
 
setArgumentType(int, String) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Builder
 
setArgumentTypes(VectorExpressionDescriptor.ArgumentType...) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Builder
 
setArgumentTypes(String...) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Builder
 
setAstNode(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFInputSpec
 
setAstStringTree(String) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setAuthenticator(HiveAuthenticationProvider) - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
 
setAuthenticator(HiveAuthenticationProvider) - Method in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
setAuthenticator(HiveAuthenticationProvider) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setAuthorizer(HiveAuthorizationProvider) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setAvgColLen(double) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setBackupChildrenTasks(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setBackupTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setBase(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLogWithBaseDoubleToDouble
 
setBase(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLogWithBaseLongToDouble
 
setBaseBigAlias(String) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
setBaseCols(List<LineageInfo.BaseColumnInfo>) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
setBaseFileName(String) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
setBaseSrc(String[]) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setBaseTableName(String) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setBaseTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
setBaseWork(Configuration, String, BaseWork) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Pushes work into the global work map
setBasicStatsState(Statistics.State) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
setBigKeysDirMap(Map<Byte, Path>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setBigKeysDirMap(Map<Byte, Path>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
set the mapping from tbl to dir for big keys.
setBigTableAlias(String) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setBigTableBucketNumMapping(Map<String, Integer>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setBigTablePartitioned(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
setBigTablePartSpecToFileMapping(Map<String, List<String>>) - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
setBigTablePartSpecToFileMapping(Map<String, List<String>>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setBigTablePosition(int) - Method in class org.apache.hadoop.hive.ql.optimizer.SortBucketJoinProcCtx
 
setBigTblPartsToBucketFileNames(Map<Partition, List<String>>) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
setBigTblPartsToBucketNumber(Map<Partition, Integer>) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
setBlockPointer(boolean) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setBody(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
setBookkeepingInfo(String, int) - Method in class org.apache.hadoop.hive.ql.exec.Stat
 
setBucketColNames(List<List<String>>) - Method in class org.apache.hadoop.hive.ql.plan.OpTraits
 
setBucketCols(List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setBucketCols(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
setBucketCols(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setBucketCols(List<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setBucketColumns(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setBucketCount(int) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
setBucketedCols(Operator<? extends OperatorDesc>, List<BucketingSortingCtx.BucketCol>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx
 
setBucketedColsByDirectory(Map<String, List<BucketingSortingCtx.BucketCol>>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx
 
setBucketFileNameMapping(Map<String, Integer>) - Method in interface org.apache.hadoop.hive.ql.exec.BucketMatcher
 
setBucketFileNameMapping(Map<String, Integer>) - Method in class org.apache.hadoop.hive.ql.exec.DefaultBucketMatcher
 
setBucketFileNameMapping(Map<String, Integer>) - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
setBucketFileNameMapping(Map<String, Integer>) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setBucketGroup(boolean) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setBucketMapJoin(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setBucketMapjoinContext(BucketMapJoinContext) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setBucketMapjoinContext(BucketMapJoinContext) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
setBucketMatcherClass(Class<? extends BucketMatcher>) - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
setBufferSize(Integer) - Method in class org.apache.hadoop.hive.ql.plan.CollectDesc
 
setBufferType(GenericUDAFMkCollectionEvaluator.BufferType) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMkCollectionEvaluator
 
setBytesValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
setCanBeMerged(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setCarryForwardNames(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
setCfg(HiveConf) - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
setCheckFileFormat(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
setChildExpressions(VectorExpression[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression
Initialize the child expressions.
setChildIndexToOriginalNumParents(Map<Integer, Integer>) - Method in class org.apache.hadoop.hive.ql.plan.DemuxDesc
 
setChildOperators(List<Operator<? extends OperatorDesc>>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setChildren(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
setChildren(List<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
setChildrenCollector(List<Operator<? extends OperatorDesc>>, OutputCollector) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorUtils
 
setChildrenCollector(List<Operator<? extends OperatorDesc>>, Map<String, OutputCollector>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorUtils
 
setChildTasks(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setClassName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
setClearAggregatorStats(boolean) - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
setClientIp(String) - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
setCloneTSOpMap(Map<TableScanOperator, TableScanOperator>) - Method in class org.apache.hadoop.hive.ql.optimizer.SkewJoinOptimizer.SkewJoinOptProcCtx
 
setClusterByExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
Set the Cluster By AST for the clause.
setCmd(String) - Method in class org.apache.hadoop.hive.ql.Context
Set the original query command.
setCmd(String) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setCode(String) - Method in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
setCodec(CompressionCodec) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
setCol(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.plan.ExtractDesc
 
setCollector(Collector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTF
Associates a collector with this UDTF.
setColList(List<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.SelectDesc
 
setCollItemDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setCollItemDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setColName(List<String>) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setColName(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
setColNames(List<String>) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DoubleColumnInList
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColAndScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColOrScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarAndColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarOrColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRoundWithNumDigitsDecimalToDecimal
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IdentityExpression
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNotNull
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNull
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColumnInList
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarDivideLongColumn
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncDoubleToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToDouble
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NotCol
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNotNull
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsNull
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatScalarCol
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringLength
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStart
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStartLen
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDF
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
setColNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldString
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColAndCol
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColOrCol
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongColumn
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsFalse
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.SelectColumnIsTrue
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColCol
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol
 
setColNum1(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColCol
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColAndCol
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColOrCol
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongColumn
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColCol
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol
 
setColNum2(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColCol
 
setColPath(String) - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
setCols(List<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
setCols(ArrayList<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setColStats(ColumnStatsDesc) - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsWork
 
setColType(List<String>) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setColType(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
setColTypes(List<TypeInfo>) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
setColumn(FieldSchema) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.BaseColumnInfo
 
setColumn(String) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
setColumnAccessInfo(ColumnAccessInfo) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Sets the column access information.
setColumnAccessInfo(ColumnAccessInfo) - Method in class org.apache.hadoop.hive.ql.QueryPlan
Sets the column access information.
setColumnDesc(ExprNodeColumnDesc) - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
setColumnExprMap(Map<String, ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setColumnIndex(int) - Method in class org.apache.hadoop.hive.ql.io.SchemaAwareCompressionInputStream
The column being read
setColumnIndex(int) - Method in class org.apache.hadoop.hive.ql.io.SchemaAwareCompressionOutputStream
The column being output
setColumnIndexes(List<Integer>) - Method in class org.apache.hadoop.hive.ql.plan.TruncateTableDesc
 
setColumnName(String) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setColumnNameList(JobConf, Operator) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
setColumnNameList(JobConf, Operator, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
setColumnNames(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
setColumnNum(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
setColumnNumber(Configuration, int) - Static method in class org.apache.hadoop.hive.ql.io.RCFileOutputFormat
set number of columns into the given configuration.
setColumns(String) - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
setColumns(String) - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
setColumns(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeDesc
 
setColumns(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
setColumnStats(Map<String, ColStatistics>) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
setColumnStats(List<ColStatistics>) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
setColumnStatsState(Statistics.State) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
setColumnType(String) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setColumnTypeList(JobConf, Operator) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
setColumnTypeList(JobConf, Operator, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
setColumnTypes(String) - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
setColumnTypes(String) - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
setColumnValueBuffer(NonSyncDataOutputBuffer, int) - Method in class org.apache.hadoop.hive.ql.io.RCFile.ValueBuffer
Deprecated. 
setCommand(String) - Method in interface org.apache.hadoop.hive.ql.HiveDriverRunHookContext
 
setCommand(String) - Method in class org.apache.hadoop.hive.ql.HiveDriverRunHookContextImpl
 
setCommandType(HiveOperation) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setComment(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
setComment(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setComment(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setCommonJoinTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
setComparison(Integer) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setComparisonExpr(ExprNodeGenericFuncDesc) - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
setComparisonOp(String) - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
setComplete(boolean) - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
setCompleteTaskList(List<TaskRunner>) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
setCompressCodec(String) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setCompressed(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setCompressedKeyLength(int) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
setCompressType(String) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setConcat(int, byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
Set a field to the concatenation of two string values.
setConditionEvaluator(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorFilterOperator
 
setConds(JoinCondDesc[]) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setConds(JoinCondDesc[]) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setConf(T) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.HiveDriverRunHookContextImpl
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.index.TableBasedIndexHandler
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.io.HivePassThroughOutputFormat
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockManagerCtx
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.GroupByOptimizerContext
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.AnnotateOpTraitsProcCtx
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.AnnotateStatsProcCtx
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.security.SessionStateConfigUserAuthenticator
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.security.SessionStateUserAuthenticator
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setConsole(SessionState.LogHelper) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setConstant(ExprNodeConstantDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
Set this argument to a constant value extracted from the expression tree.
setConstantDesc(ExprNodeConstantDesc) - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
setConstExpr(ExprNodeConstantDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
setConstituentInputIsReady(Input) - Method in class org.apache.hadoop.hive.ql.exec.tez.tools.TezMergedLogicalInput
 
setContext(HiveLockManagerCtx) - Method in class org.apache.hadoop.hive.ql.lockmgr.DbLockManager
 
setContext(HiveLockManagerCtx) - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
setContext(HiveLockManagerCtx) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
setContext(HiveLockManagerCtx) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
setContext(Context) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
setContext(Context) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setConvertedAutomaticallySMBJoin(boolean) - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
setConvertedJoinOps(Set<JoinOperator>) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
setCountDistint(long) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setCounters(Counters) - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
setCountOfOne(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setCountOnAllCols(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setCpuMSec(long) - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
setCreateDatabaseDesc(CreateDatabaseDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
Set Create Database descriptor
setCreateFunctionDesc(CreateFunctionDesc) - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
setCreateIndexDesc(CreateIndexDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setCreateTableGrants(CreateTableAutomaticGrant) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setCreateTblDesc(CreateTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setCreateTblLikeDesc(CreateTableLikeDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setCreateViewDesc(CreateViewDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setCreateVwDesc(CreateViewDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setCurrAliasId(String) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setCurrentBigBucketFile(String) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
setCurrentBlockStart(long) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setCurrentDatabase(String) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setCurrentInputPath(Path) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
setCurrentRole(String) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessController
 
setCurrentRole(String) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
Set the current role to roleName argument
setCurrentRole(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
setCurrentRole(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
setCurrentRow(long) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setCurrentSessionState(SessionState) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
Sets the given session state in the thread local var for sessions.
setCurrentTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
setCurrentTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinResolver.SkewJoinProcCtx
 
setCurrMapJoinOp(AbstractMapJoinOperator<? extends MapJoinDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
setCurrPart(PartitionDesc) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
setCurrTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setCurrTbl(TableDesc) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
setCurrTopOp(Operator<? extends OperatorDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setCurrUnionOp(UnionOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setCursor(int) - Method in class org.apache.hadoop.hive.ql.exec.FooterBuffer
 
setCustomBucketMapJoin(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setD(String) - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
setData(HiveLockObject.HiveLockObjectData) - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
setDatabase(Database) - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
setDatabaseName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
setDatabaseName(String) - Method in class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
setDatabaseName(String) - Method in class org.apache.hadoop.hive.ql.plan.DropDatabaseDesc
 
setDatabaseName(String) - Method in class org.apache.hadoop.hive.ql.plan.LockDatabaseDesc
 
setDatabaseName(String) - Method in class org.apache.hadoop.hive.ql.plan.SwitchDatabaseDesc
 
setDatabaseName(String) - Method in class org.apache.hadoop.hive.ql.plan.UnlockDatabaseDesc
 
setDatabaseProperties(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
setDatabaseProperties(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
setDataLocation(Path) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setDataSize(long) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.index.IndexMetadataChangeWork
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableAlterPartDesc
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.plan.RenamePartitionDesc
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowColumnsDesc
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
setDecimalPlaces(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRoundWithNumDigitsDecimalToDecimal
 
setDecimalValue(Decimal128) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
setDefault() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
setDefaultArgOI(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
setDefaultDirName(String) - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
setDefaultKey(String) - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
setDefaultPartitionName(String) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setDefaultSerdeProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setDefaultSerName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setDefaultValueConverter(ObjectInspectorConverters.Converter) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
setDeferredRebuild(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setDenominator(int) - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Sets the denominator.
setDependency(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setDesc(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
setDescFuncDesc(DescFunctionDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setDescFunctionDesc(DescFunctionDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setDescTblDesc(DescTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setDestForAlias(String, Table) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
setDestForAlias(String, Partition) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
setDestForAlias(String, String, boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
setDestForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setDestination(String) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFQueryInputDef
 
setDestinationTable(Table) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableExchangePartition
 
setDestLimit(String, Integer) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setDestTableId(int) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setDestTableId(int) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setDeterministic(boolean) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
sets the deterministic flag for this expression.
setDir(String) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
setDirect(boolean) - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
setDirectFetchOp(Map<MapJoinOperator, List<Operator<? extends OperatorDesc>>>) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
setDirection(WindowingSpec.Direction) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.BoundarySpec
 
setDirection(WindowingSpec.Direction) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.CurrentRowSpec
 
setDirection(WindowingSpec.Direction) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.RangeBoundarySpec
 
setDirection(WindowingSpec.Direction) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.ValueBoundarySpec
 
setDirection(WindowingSpec.Direction) - Method in class org.apache.hadoop.hive.ql.plan.ptf.BoundaryDef
 
setDirectWorks(Map<MapJoinOperator, List<Operator<? extends OperatorDesc>>>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
setDirName(Path) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setDirToTaskMap(HashMap<Path, Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx
 
setDistinct(boolean) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFunctionSpec
 
setDistinct(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
setDistinct(boolean) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setDistinct(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
setDistinctColumnIndices(List<List<Integer>>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setDistinctFuncExprsForClause(String, List<ASTNode>) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setDistKeyLength(int) - Method in class org.apache.hadoop.hive.ql.io.HiveKey
 
setDistributeByExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
Set the Distribute By AST for the clause.
setDivisor(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.PosModDoubleToDouble
 
setDivisor(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.PosModLongToLong
 
setDone(boolean) - Static method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapper
 
setDone() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setDone() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setDoneJoins(Set<JoinOperator>) - Method in class org.apache.hadoop.hive.ql.optimizer.SkewJoinOptimizer.SkewJoinOptProcCtx
 
setDontResetAggrsDistinct(boolean) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setDoubleValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
setDPColNames(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setDPCtx(String, DynamicPartitionCtx) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
setDPCtx(DynamicPartitionCtx) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
setDPCtx(DynamicPartitionCtx) - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
setDpSortState(FileSinkDesc.DPSortState) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setDropDatabaseDesc(DropDatabaseDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
Set Drop Database descriptor
setDropFunctionDesc(DropFunctionDesc) - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
setDropIdxDesc(DropIndexDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setDropIfExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setDroppedColumns(List<Integer>) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
setDropTblDesc(DropTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setDummyOps(List<HashTableDummyOperator>) - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
setDummyParentOp(List<Operator<? extends OperatorDesc>>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
setDummyParentOp(List<Operator<? extends OperatorDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
setDumpFilePrefix(String) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setDumpFilePrefix(String) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setDynPartCtx(DynamicPartitionCtx) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
setDynPartCtx(DynamicPartitionCtx) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
setDynPartCtx(DynamicPartitionCtx) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setElement(int, int, ColumnVector) - Method in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
 
setElement(int, int, ColumnVector) - Method in class org.apache.hadoop.hive.ql.exec.vector.ColumnVector
Set the element in this column vector from the given input vector.
setElement(int, int, ColumnVector) - Method in class org.apache.hadoop.hive.ql.exec.vector.DecimalColumnVector
 
setElement(int, int, ColumnVector) - Method in class org.apache.hadoop.hive.ql.exec.vector.DoubleColumnVector
 
setElement(int, int, ColumnVector) - Method in class org.apache.hadoop.hive.ql.exec.vector.LongColumnVector
 
setEnd(WindowingSpec.BoundarySpec) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFrameSpec
 
setEnd(BoundaryDef) - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFrameDef
 
setEndBinarySearch(boolean) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setError(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
setErrorOnSrcEmpty(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CopyWork
 
setErrRecordReaderClass(Class<? extends RecordReader>) - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
setEval(GenericUDAFEvaluator) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteQueryUsingAggregateIndexCtx
 
setExecContext(ExecMapperContext) - Method in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
setExecContext(ExecMapperContext) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setExitVal(int) - Method in class org.apache.hadoop.hive.ql.exec.TaskResult
 
setExitVal(int, Throwable) - Method in class org.apache.hadoop.hive.ql.exec.TaskResult
 
setExpectView(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setExpectView(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
setExplain(boolean) - Method in class org.apache.hadoop.hive.ql.Context
Set the context on whether the current query is an explain query.
setExplainLogical(boolean) - Method in class org.apache.hadoop.hive.ql.Context
Set the context on whether the current query is a logical explain query.
setExpr(ExprNodeGenericFuncDesc) - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
setExpr(String) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
setExpression(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionExpression
 
setExpression(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.ValueBoundarySpec
 
setExpression(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowExpressionSpec
 
setExpressionDef(PTFExpressionDef) - Method in class org.apache.hadoop.hive.ql.plan.ptf.ValueBoundaryDef
 
setExpressionMap(Map<String, ASTNode>) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
setExpressions(ArrayList<PTFInvocationSpec.OrderExpression>) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderSpec
 
setExpressions(ArrayList<PTFInvocationSpec.PartitionExpression>) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionSpec
 
setExpressions(ArrayList<ArrayList<ASTNode>>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setExpressions(ArrayList<OrderExpressionDef>) - Method in class org.apache.hadoop.hive.ql.plan.ptf.OrderDef
 
setExpressions(List<PTFExpressionDef>) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionDef
 
setExpressionTreeString(String) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFExpressionDef
 
setExpressionTreeString(String) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFInputDef
 
setExprEvaluator(ExprNodeEvaluator) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFExpressionDef
 
setExprEvaluator(ExprNodeEvaluator) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
setExprNode(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFExpressionDef
 
setExprNodeDesc(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc.ExprNodeDescEqualityWrapper
 
setExprResolver(boolean) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
setExprs(ArrayList<ASTNode>) - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Sets the expression list.
setExprs(Map<Byte, List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setExprs(Map<Byte, List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setExprToColumnAlias(ASTNode, String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setExt(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
setExt(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
setExt(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
setExtended(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
setExtended(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setExternal(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setExternal(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setFeedSubscribers(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setFetchOperators(Map<String, FetchOperator>) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
setFetchSink(ListSinkOperator) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setFetchSource(Operator<?>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setFetchTabledesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setFetchTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
setFetchTask(FetchTask) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
setFetchTask(FetchTask) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setFetchTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setFetchTask(FetchTask) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setField(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
setFieldDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setFieldDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setFieldEscape(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setFieldEscape(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setFieldName(String) - Method in class org.apache.hadoop.hive.ql.plan.ExplosionDesc
 
setFieldName(String) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
setFields(List<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setFile(String) - Method in class org.apache.hadoop.hive.ql.log.PidDailyRollingFileAppender
 
setFileId(String) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
setFileKey(String) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
setFilterCondition(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorFilterOperator
 
setFilterExpr(ExprNodeGenericFuncDesc) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setFilterMap(int[][]) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setFilterMap(int[][]) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setFilterMap(int[][]) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setFilters(ArrayList<ArrayList<ASTNode>>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setFilters(Map<Byte, List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setFilters(Map<Byte, List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setFiltersForPushing(ArrayList<ArrayList<ASTNode>>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setFinalMapRed(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
setFirst(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setFirstArgOI(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
setFixedAsSorted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setFnName(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator
 
setFollowedByGroupBy(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
setFormatted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
setFormatted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setFormatted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ShowIndexesDesc
 
setFromBytes(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
setFsopToTable(Map<FileSinkOperator, Table>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setFullyQualifiedColName(String) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setFunc(StringUnaryUDF.IUDFUnaryString) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDF
 
setFuncDef(PartitionedTableFunctionDef) - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
setFunction(PTFInvocationSpec.PartitionedTableFunctionSpec) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec
 
setFunctionName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
setFunctionName(String) - Method in class org.apache.hadoop.hive.ql.plan.DropFunctionDesc
 
setfWork(FetchWork) - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsWork
 
setGatheringStats(boolean) - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
setGatherStats(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setGatherStats(boolean) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setGbKeyNameList(Set<String>) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setGbyKeysFetchException(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setGenericUDAFEvaluator(GenericUDAFEvaluator) - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
setGenericUDAFEvaluatorClassName(String) - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
setGenericUDAFName(String) - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
setGenericUDAFWritableEvaluator(GenericUDAFEvaluator) - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
setGenericUDF(GenericUDF) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
setGenericUDFClassName(String) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setGenericUDTF(GenericUDTF) - Method in class org.apache.hadoop.hive.ql.plan.UDTFDesc
 
setGlobalLimitCtx(GlobalLimitCtx) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setGrant(boolean) - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
setGrantDesc(GrantDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
setGrantor(String) - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
setGrantor(String) - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
setGrantor(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
setGrantorType(PrincipalType) - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
setGrantorType(PrincipalType) - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
setGrantorType(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
setGrantRevokeRoleDDL(GrantRevokeRoleDDL) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setGrantTime(int) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
setGroup(boolean) - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
setGroupByExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setGroupByMemoryUsage(float) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setGroupingSetPosition(int) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setGroupingSetsPresent(boolean) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setGroupKeyNotReductionKey(boolean) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setGroupKeyObject(Object) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setGroupKeyObjectInspector(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setGroupOpToInputTables(Map<GroupByOperator, Set<String>>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setHadoopSupportsSplittable(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setHandleSkewJoin(boolean) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setHandleSkewJoin(boolean) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
set to handle skew join in this join op.
setHasClusterBy(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHasDistributeBy(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHasDynamicPartitions(boolean) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
setHasDynamicPartitions(boolean) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
setHasGroupBy(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHashCode(int) - Method in class org.apache.hadoop.hive.ql.io.HiveKey
 
setHashKey() - Method in class org.apache.hadoop.hive.ql.exec.KeyWrapper
 
setHashKey() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
setHashtableMemoryUsage(float) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setHashTableMemoryUsage(float) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setHasJoinFollowedByGroupBy(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHasMapGroupBy(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHasOrderBy(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHasPTF(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHasSortBy(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHasStagedAlias(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
setHasTransformOrUDTF(boolean) - Method in class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
setHasWindowing(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setHavingExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setHDFSCleanup(boolean) - Method in class org.apache.hadoop.hive.ql.Context
 
setHdfsTmpDir(Path) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
setHiddenVirtualCol(boolean) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setHints(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setHiveLockMode(HiveLockMode) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock
 
setHiveLockObject(HiveLockObject) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock
 
setHiveLocks(List<HiveLock>) - Method in class org.apache.hadoop.hive.ql.Context
 
setHiveObj(PrivilegeObjectDesc) - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
setHiveTxnManager(HiveTxnManager) - Method in class org.apache.hadoop.hive.ql.Context
 
setHiveVariables(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setHoldDDLTime(boolean) - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
setHookType(HookContext.HookType) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
setId(String) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setId(String) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setId(String) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setIdToTableMap(Map<String, String>) - Method in interface org.apache.hadoop.hive.ql.history.HiveHistory
Set the id to table name map
setIdToTableMap(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
 
setIdToTableNameMap(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setIdToTableNameMap(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setIdxProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setIfExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DropDatabaseDesc
 
setIfExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
setIfNotExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
setIfNotExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
setIfNotExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setIfNotExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setIfNotExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setIgnoreProtection(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
setIndex(LineageCtx.Index) - Method in class org.apache.hadoop.hive.ql.session.LineageState
Sets the index for the lineage state.
setIndexComment(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setIndexedCols(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setIndexInputFormat(String) - Method in class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
setIndexIntermediateFile(String) - Method in class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
setIndexName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
setIndexName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setIndexName(String) - Method in class org.apache.hadoop.hive.ql.plan.DropIndexDesc
 
setIndexTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setIndexTbl(String) - Method in class org.apache.hadoop.hive.ql.index.IndexMetadataChangeWork
 
setIndexTypeHandlerClass(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setInheritTableSpecs(boolean) - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
setInitialized() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setInListValues(Decimal128[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalColumnInList
 
setInListValues(double[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DoubleColumnInList
 
setInListValues(Decimal128[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDecimalColumnInList
 
setInListValues(double[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterDoubleColumnInList
 
setInListValues(long[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterLongColumnInList
 
setInListValues(byte[][]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStringColumnInList
 
setInListValues(Decimal128[]) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.IDecimalInExpr
 
setInListValues(double[]) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.IDoubleInExpr
 
setInListValues(long[]) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.ILongInExpr
 
setInListValues(byte[][]) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.IStringInExpr
 
setInListValues(long[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColumnInList
 
setInListValues(byte[][]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringColumnInList
 
setInput(PTFInvocationSpec.PTFInputSpec) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
setInput(PTFInputDef) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
setInputAliases(String[]) - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
setInputAttributes(Configuration, MapWork) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Set hive input format, and input format file if necessary.
setInputCol(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToString
 
setInputCol(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringColumnInList
 
setInputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToDecimal
 
setInputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToDate
 
setInputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDate
 
setInputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDecimal
 
setInputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalToStringUnaryUDF
 
setInputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToDouble
 
setInputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToLong
 
setInputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDoubleToDecimal
 
setInputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToDecimal
 
setInputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongToStringUnaryUDF
 
setInputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDFDirect
 
setInputColumns(int[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorCoalesce
 
setInputDir(List<Path>) - Method in class org.apache.hadoop.hive.ql.parse.AlterTablePartMergeFilesDesc
 
setInputDir(Path) - Method in class org.apache.hadoop.hive.ql.plan.TruncateTableDesc
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFAvgDecimal
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCount
 
setInputExpression(VectorExpression) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFSumDecimal
 
setInputExpressionType(int, VectorExpressionDescriptor.InputExpressionType) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Builder
 
setInputExpressionTypes(VectorExpressionDescriptor.InputExpressionType...) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Builder
 
setInputFileChangeSensitive(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
setInputFileFormatClass(Class<? extends InputFormat>) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
setInputFileFormatClass(Class<? extends InputFormat>) - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
setInputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
setInputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setInputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setInputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setInputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setInputformat(String) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setInputFormatClass(Class<? extends InputFormat>) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
setInputFormatClass(Class<? extends InputFormat>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setInputFormatClass(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setInputFormatClassName(String) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
setInputFormatClassName(String) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
setInputFormatSorted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setInputObjInspectors(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setInputPath(Path) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setInputPath(Path) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
setInputPaths(JobConf, List<Path>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
setInputPaths add all the paths in the provided list to the Job conf object as input paths for the job.
setInputPaths(List<Path>) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
setInputPaths(List<Path>) - Method in class org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanWork
 
setInputPaths(Path) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
setInputPruning(boolean) - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Sets the flag that indicates whether input pruning is possible or not.
setInputRR(RowResolver) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
setInputs(Map<String, LogicalInput>) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezContext
 
setInputs(Set<ReadEntity>) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
setInputs(HashSet<ReadEntity>) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setInputs(HashSet<ReadEntity>) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setInputs(HashSet<ReadEntity>) - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
setInputs(HashSet<ReadEntity>) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setInputToDPCols(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setInputTypes(VectorExpression.Type...) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression
Set more detailed types to distinguish certain types that is represented in same VectorExpressionDescriptor.ArgumentTypes.
setInRecordWriterClass(Class<? extends RecordWriter>) - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
setInternalName(String) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setInvRslvMap(HashMap<String, String[]>) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
setIoCxt(IOContext) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
setIOExceptions(boolean) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setIsAlterViewAs(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setIsAnalyzeCommand(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setIsBinarySearching(boolean) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setIsCandidate(ExprNodeDesc, boolean) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Marks the specified expr to the specified value.
setIsCascade(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DropDatabaseDesc
 
setIsConstant(boolean) - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
setIsDfsDir(boolean) - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
setIsDfsDir(boolean) - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
setIsExprResolver(boolean) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
setIsHidden(boolean) - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
setIsHiveServerQuery(boolean) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setIsInsertToTable(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setIsList(Boolean) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
setIsMetadataOnly(boolean) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setIsPartitionColOrVirtualCol(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
setIsQuery(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setIsSamplingPred(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
setIsSilent(boolean) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setIsSubQuery(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.TezBucketJoinProcCtx
 
setIsVerbose(boolean) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setJc(JobConf) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
setJobFlowCorrelation(boolean, List<ReduceSinkOperator>) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.IntraQueryCorrelation
 
setJobId(JobID) - Method in class org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper
 
setJobId(String) - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
setJobProperties(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
setJoinAliases(List<String>) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
setJoinCond(JoinCond[]) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setJoinContext(Map<JoinOperator, QBJoinTree>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setJoinExpr(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setJoinSrc(QBJoinTree) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setJoinTree(QBJoinTree) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setJoinType(JoinType) - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
setKeyAndValueDesc(ReduceWork, ReduceSinkOperator) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Set key and value descriptor
setKeyAndValueDesc(ReduceWork, Operator<? extends OperatorDesc>) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
set key and value descriptor.
setKeyAndValueDescForTaskTree(Task<? extends Serializable>) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Set the key and value description for all the tasks rooted at the given task.
setKeyBuffer(RCFile.KeyBuffer) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
setKeyCols(ArrayList<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setKeyDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
If the plan has a reducer and correspondingly a reduce-sink, then store the TableDesc pointing to keySerializeInfo of the ReduceSink
setKeyEval(VectorExpression[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator
 
setKeyExpressions(VectorExpression[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
setKeyExprMap(Map<Byte, List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.optimizer.SortBucketJoinProcCtx
 
setKeyLength(int) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
setKeyObject(List<Object>) - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
setKeys(ArrayList<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setKeys(Map<Byte, List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setKeys(Map<Byte, List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setKeySerializeInfo(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setKeysSerializeInfos(List<TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.DemuxDesc
 
setKeyTableDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setKeyTableDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setKeyTblDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setKeyTblDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setLang(String) - Method in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setLastCommand(String) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setLastInputPath(Path) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
setLastMapRedStatsList(List<MapRedStats>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setLastReduceLimitDesc(LimitDesc) - Method in class org.apache.hadoop.hive.ql.parse.GlobalLimitCtx
 
setLbCtx(ListBucketingCtx) - Method in class org.apache.hadoop.hive.ql.parse.AlterTablePartMergeFilesDesc
 
setLbCtx(ListBucketingCtx) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
setLbCtx(ListBucketingCtx) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setLbCtx(ListBucketingCtx) - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
setLbCtx(ListBucketingCtx) - Method in class org.apache.hadoop.hive.ql.plan.TruncateTableDesc
 
setLbLocationMap(Map<List<String>, String>) - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
setLeastNumRows(int) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setLeastRows(int) - Method in class org.apache.hadoop.hive.ql.plan.LimitDesc
 
setLeft(int) - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
setLeft(int) - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
setLeftAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
set left alias for the join expression.
setLeftAliases(String[]) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setLength(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStartLen
 
setLikeTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setLimit(int) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setLimit(int) - Method in class org.apache.hadoop.hive.ql.plan.LimitDesc
 
setLineage(Path, LineageInfo.DataContainer, List<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.session.LineageState
Set the lineage information for the associated directory.
setLineageInfo(LineageInfo) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Sets the lineage information.
setLineageInfo(LineageInfo) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
Sets the lineage information.
setLineageInfo(LineageInfo) - Method in class org.apache.hadoop.hive.ql.QueryPlan
Sets the lineage information.
setLineDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setLineDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setLinfo(LineageInfo) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
setLinkedFileDescTasks(Map<FileSinkDesc, Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setLinkedFileSink(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setLinkedFileSinkDesc(List<FileSinkDesc>) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setListBucketingCtx(ListBucketingCtx) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
setListBucketingCtx(ListBucketingCtx) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
setListGroupByOperatorsProcessed(List<GroupByOperator>) - Method in class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.GroupByOptimizerContext
 
setListGroupingSets(List<Integer>) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setListMapJoinOpsNoReducer(List<AbstractMapJoinOperator<? extends MapJoinDesc>>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setListMapJoins(List<AbstractMapJoinOperator<? extends MapJoinDesc>>) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
setListRejectedMapJoins(List<AbstractMapJoinOperator<? extends MapJoinDesc>>) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
setListTasks(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
setListTasks(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
setListTopOperators(List<Operator<? extends OperatorDesc>>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
setListWorks(List<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalWork
 
setLlInfo(LeadLagInfo) - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
setLoadFileWork(List<LoadFileDesc>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setLoadFileWork(LoadFileDesc) - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
setLoadTableWork(List<LoadTableDesc>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setLoadTableWork(LoadTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
setLocalDirectoryDesc(CreateTableDesc) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setLocalMapRedErrors(Map<String, List<String>>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setLocalMode(boolean) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setLocalTmpDir(Path) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
setLocalWork(MapredLocalWork) - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext
 
setLocalWork(MapredLocalWork) - Method in class org.apache.hadoop.hive.ql.plan.SMBJoinDesc
 
setLocation(String) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
setLocation(String) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
setLocation(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setLocation(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setLocation(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setLocation(String) - Method in class org.apache.hadoop.hive.ql.plan.RenamePartitionDesc
 
setLocationUri(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
setLockDatabaseDesc(LockDatabaseDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setLockTblDesc(LockTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setLogical(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setLongValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
setLongValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
setLongValue(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
setLongValue(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
setMacroName(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMacro
 
setMapAliases(List<String>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setMapCurrCtx(LinkedHashMap<Operator<? extends OperatorDesc>, GenMRProcContext.GenMapRedCtx>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setMapGroupBy(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setMapJoinBigTableAlias(String) - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
setMapJoinContext(Map<MapJoinOperator, QBJoinTree>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setMapJoinRemoved(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setMapKeyDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setMapKeyDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setMapLocalWork(MapredLocalWork) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setMapOnlySubq(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext
 
setMapOnlySubq(int, boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
setMapperCannotSpanPartns(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setMapRedWork(Configuration, MapredWork, Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
setMapSide(boolean) - Method in class org.apache.hadoop.hive.ql.plan.PTFDesc
 
setMapSideJoin(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setMapWork(Configuration, MapWork) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
setMapWork(Configuration, MapWork, Path, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
setMapWork(MapWork, ParseContext, Set<ReadEntity>, PrunedPartitionList, Operator<? extends OperatorDesc>, String, HiveConf, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
initialize MapWork
setMapWork(MapWork) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
setMaxPartitionsPerNode(int) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setMaxRows(int) - Method in class org.apache.hadoop.hive.ql.Driver
Set the maximum number of rows returned by getResults
setMaxRows(int) - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
Set the maximum number of rows returned by fetch.
setMaxSplitSize(Long) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setMaxStatsKeyPrefixLength(int) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setMaxStatsKeyPrefixLength(int) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setMemoryThreshold(float) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setMergeFilesDesc(AlterTablePartMergeFilesDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setMergeOutputPath(JobConf, Path) - Static method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileBlockMergeOutputFormat
 
setMetaStoreHandler(HiveMetaStore.HMSHandler) - Method in class org.apache.hadoop.hive.ql.security.authorization.DefaultHiveMetastoreAuthorizationProvider
 
setMetaStoreHandler(HiveMetaStore.HMSHandler) - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveMetastoreAuthorizationProvider
Allows invoker of HiveMetaStoreAuthorizationProvider to send in a hive metastore handler that can be used to make calls to test whether or not authorizations can/will succeed.
setMetaStoreHandler(HiveMetaStore.HMSHandler) - Method in class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider
 
setMetaStoreHandler(HiveMetaStore.HMSHandler) - Method in class org.apache.hadoop.hive.ql.security.HadoopDefaultMetastoreAuthenticator
 
setMetaStoreHandler(HiveMetaStore.HMSHandler) - Method in interface org.apache.hadoop.hive.ql.security.HiveMetastoreAuthenticationProvider
Allows invoker of HiveMetastoreAuthenticationProvider to send in a hive metastore handler that can be used to provide data for any authentication that needs to be done.
setMinSplitSize(Long) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setMinSplitSizePerNode(Long) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setMinSplitSizePerRack(Long) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setMode(VectorExpressionDescriptor.Mode) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Builder
 
setMode(HiveLockMode) - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObj
 
setMode(GenericUDAFEvaluator.Mode) - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
setMode(GroupByDesc.Mode) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setMode(String) - Method in class org.apache.hadoop.hive.ql.plan.LockDatabaseDesc
 
setMode(String) - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
setMode(short) - Method in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeScope
 
setMsckDesc(MsckDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setMultiFilesDesc(LoadMultiFilesDesc) - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
setMultiFileSpray(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setMvTask(List<Task<MoveWork>>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setName(String) - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
setName(String) - Method in class org.apache.hadoop.hive.ql.metadata.DummyPartition
 
setName(String) - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
setName(String) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
setName(String) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFunctionSpec
 
setName(String) - Method in class org.apache.hadoop.hive.ql.plan.BaseWork
 
setName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
setName(String) - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
setName(String) - Method in class org.apache.hadoop.hive.ql.plan.PrincipalDesc
 
setName(String) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
setName(String) - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
setNamed(String) - Method in class org.apache.hadoop.hive.ql.processors.CompileProcessor
 
setNameToSplitSample(HashMap<String, SplitSample>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setNameToSplitSample(HashMap<String, SplitSample>) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setNeededColumnIDs(List<Integer>) - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
setNeededColumns(List<String>) - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
setNeedLock(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setNeedLockMgr(boolean) - Method in class org.apache.hadoop.hive.ql.Context
 
setNeedsTagging(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
setNewColComment(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setNewColName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setNewCols(ArrayList<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setNewColType(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setNewLocation(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setNewName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setNewParentIndexToOldParentIndex(Map<Integer, Integer>) - Method in class org.apache.hadoop.hive.ql.plan.MuxDesc
 
setNewPartSpec(LinkedHashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.RenamePartitionDesc
 
setNewTag(Integer, Integer, Integer) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.IntraQueryCorrelation
 
setNewTagToChildIndex(Map<Integer, Integer>) - Method in class org.apache.hadoop.hive.ql.plan.DemuxDesc
 
setNewTagToOldTag(Map<Integer, Integer>) - Method in class org.apache.hadoop.hive.ql.plan.DemuxDesc
 
setNextBlockStart(long) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setNoNullFields(VectorizedRowBatch) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
Iterates thru all the column vectors and sets noNull to specified value.
setNoOuterJoin(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setNoOuterJoin(boolean) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setNoOuterJoin(boolean) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setNoScanAnalyzeCommand(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setNoScanAnalyzeCommand(boolean) - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
setNoSemiJoin(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setNoSkewTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx
 
setNoStatsAggregator(boolean) - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
setNullAndDivBy0DataEntriesDouble(DoubleColumnVector, boolean, int[], int, LongColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NullUtil
Set all the entries for which denoms array contains zeroes to NULL; sets all the data values for NULL entries for DoubleColumnVector.NULL_VALUE.
setNullAndDivBy0DataEntriesDouble(DoubleColumnVector, boolean, int[], int, DoubleColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NullUtil
Set all the entries for which denoms array contains zeroes to NULL; sets all the data values for NULL entries for DoubleColumnVector.NULL_VALUE.
setNullAndDivBy0DataEntriesLong(LongColumnVector, boolean, int[], int, LongColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NullUtil
Set all the entries for which denoms array contains zeroes to NULL; sets all the data values for NULL entries for LongColumnVector.NULL_VALUE.
setNullAndDivBy0DataEntriesLong(LongColumnVector, boolean, int[], int, DoubleColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NullUtil
Set all the entries for which denoms array contains zeroes to NULL; sets all the data values for NULL entries for LongColumnVector.NULL_VALUE.
setNullColIsNullValue(ColumnVector, int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
Sets the IsNull value for ColumnVector at specified index
setNullDataEntriesDecimal(DecimalColumnVector, boolean, int[], int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NullUtil
Follow the convention that null decimal values are internally set to the smallest positive value available.
setNullDataEntriesDouble(DoubleColumnVector, boolean, int[], int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NullUtil
Set the data value for all NULL entries to NaN
setNullDataEntriesLong(LongColumnVector, boolean, int[], int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NullUtil
Set the data value for all NULL entries to the designated NULL_VALUE.
setNullFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
Set null format string
setNullOutputEntriesColScalar(ColumnVector, boolean, int[], int) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NullUtil
 
setNullSafes(ArrayList<Boolean>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setNullSafes(boolean[]) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setNumArguments(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Builder
 
setNumberBuckets(int) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setNumBuckets(int) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setNumBuckets(int) - Method in class org.apache.hadoop.hive.ql.optimizer.TezBucketJoinProcCtx
 
setNumBuckets(int) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
setNumBuckets(int) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setNumBuckets(int) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setNumBuckets(int) - Method in class org.apache.hadoop.hive.ql.plan.OpTraits
 
setNumBuckets(int) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setNumDay(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
setNumDistributionKeys(int) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setNumDPCols(int) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setNumerator(int) - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Sets the numerator.
setNumFalses(long) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setNumFields(int) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcStruct
Change the number of fields in the struct.
setNumFiles(int) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setNumInputs(int) - Method in class org.apache.hadoop.hive.ql.plan.UnionDesc
 
setNumMap(int) - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
setNumMapTasks(Integer) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setNumNulls(long) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setNumReduce(int) - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
setNumReducers(int) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setNumReduceTasks(Integer) - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
setNumRows(long) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
setNumSelColumns(int) - Method in class org.apache.hadoop.hive.ql.plan.LateralViewJoinDesc
 
setNumSPCols(int) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setNumTrues(long) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setObj(HiveLockObject) - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObj
 
setObject(String) - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
setOI(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFExpressionDef
 
setOI(StructObjectInspector) - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
setOldColName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setOldName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setOldPartSpec(LinkedHashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.RenamePartitionDesc
 
setOp(AlterIndexDesc.AlterIndexTypes) - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
setOp(AlterTableDesc.AlterTableTypes) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setOpcode(QBExpr.Opcode) - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
setOperation(RoleDDLDesc.RoleOperation) - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
setOperator(boolean) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
setOperatorId(String) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setOpParseCtx(LinkedHashMap<Operator<? extends OperatorDesc>, OpParseContext>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setOpParseCtxMap(LinkedHashMap<Operator<? extends OperatorDesc>, OpParseContext>) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setOpPartToSkewedPruner(HashMap<TableScanOperator, Map<String, ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setOpTaskMap(HashMap<Operator<? extends OperatorDesc>, Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setOpToPartPruner(HashMap<TableScanOperator, ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setOpToSamplePruner(HashMap<TableScanOperator, FilterDesc.sampleDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner.SamplePrunerCtx
 
setOpToSamplePruner(HashMap<TableScanOperator, FilterDesc.sampleDesc>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setOpTraits(OpTraits) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setOpTraits(OpTraits) - Method in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
setOpTraits(OpTraits) - Method in interface org.apache.hadoop.hive.ql.plan.OperatorDesc
 
setOrder(PTFInvocationSpec.Order) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderExpression
 
setOrder(PTFInvocationSpec.OrderSpec) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
setOrder(PTFInvocationSpec.OrderSpec) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowSpec
 
setOrder(PTFInvocationSpec.Order) - Method in class org.apache.hadoop.hive.ql.plan.ptf.OrderExpressionDef
 
setOrder(OrderDef) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
setOrder(String) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setOrderByExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setOrderSpec(PTFInvocationSpec.OrderSpec) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitioningSpec
 
setOrigin(ASTNodeOrigin) - Method in class org.apache.hadoop.hive.ql.parse.ASTNode
Tag this ASTNode with information about the object from which this node originated.
setOriginalTracker(String) - Method in class org.apache.hadoop.hive.ql.Context
 
setOrReplace(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setOuterLV(boolean) - Method in class org.apache.hadoop.hive.ql.plan.UDTFDesc
 
setOuterQueryLimit(int) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setOutputCol(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToString
 
setOutputCol(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRand
 
setOutputCol(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRandNoSeed
 
setOutputCollector(OutputCollector) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setOutputCollector(OutputCollector) - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToDecimal
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToDate
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDate
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringToDecimal
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColAndCol
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ColOrCol
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalToStringUnaryUDF
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DoubleColumnInList
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDoubleToDecimal
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncLongToDecimal
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRoundWithNumDigitsDecimalToDecimal
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringColumnStringScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprStringScalarStringScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNotNull
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IsNull
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColumnInList
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarDivideLongColumn
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongToStringUnaryUDF
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncDoubleToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToDouble
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathFuncLongToLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.NotCol
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringColumnInList
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColCol
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatScalarCol
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringLength
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStart
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStartLen
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDF
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDFDirect
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorCoalesce
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColCol
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldString
 
setOutputColumn(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
setOutputColumnNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setOutputColumnNames(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setOutputColumnNames(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setOutputColumnNames(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.SelectDesc
 
setOutputDir(Path) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.MergeWork
 
setOutputDir(Path) - Method in class org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateWork
 
setOutputDir(Path) - Method in class org.apache.hadoop.hive.ql.parse.AlterTablePartMergeFilesDesc
 
setOutputDir(Path) - Method in class org.apache.hadoop.hive.ql.plan.TruncateTableDesc
 
setOutputFileFormatClass(Class<?>) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
setOutputFileFormatClass(Class<?>) - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
setOutputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
setOutputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setOutputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setOutputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setOutputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setOutputFormatClass(Class<? extends HiveOutputFormat>) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
setOutputFormatClass(Class<? extends HiveOutputFormat>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setOutputFormatClass(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setOutputInternalColNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.LateralViewJoinDesc
 
setOutputKeyColumnNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setOutputName(String) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setOutputs(Map<String, LogicalOutput>) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezContext
 
setOutputs(Set<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
setOutputs(HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setOutputs(HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
setOutputs(HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setOutputShape(ShapeDetails) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFInputDef
 
setOutputType(String) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
setOutputType(String) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression
Set type of the output column.
setOutputValueColumnNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setOutRecordReaderClass(Class<? extends RecordReader>) - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
setOutWriters(FileSinkOperator.RecordWriter[]) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
 
setOverriddenConfigurations(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setOwner(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setOwnerPrincipal(PrincipalDesc) - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
setP(Partition) - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
setParameters(ArrayList<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
setParentDir(Path) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setParentOperators(List<Operator<? extends OperatorDesc>>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setParentTasks(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setParentToInput(Map<Integer, String>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setParentToKeyCols(List<List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.MuxDesc
 
setParentToOutputKeyColumnNames(List<List<String>>) - Method in class org.apache.hadoop.hive.ql.plan.MuxDesc
 
setParentToOutputValueColumnNames(List<List<String>>) - Method in class org.apache.hadoop.hive.ql.plan.MuxDesc
 
setParentToTag(List<Integer>) - Method in class org.apache.hadoop.hive.ql.plan.MuxDesc
 
setParentToValueCols(List<List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.MuxDesc
 
setParseContext(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.AnnotateOpTraitsProcCtx
 
setParseContext(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
setParseContext(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.AnnotateStatsProcCtx
 
setParseContext(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext
 
setParseContext(ParseContext) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setParseCtx(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setParseCtx(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
setParseCtx(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinResolver.SkewJoinProcCtx
 
setParseTree(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setPartColNames(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setPartCols(List<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setPartCols(ArrayList<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setPartCols(List<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setPartColumns(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setPartDesc(ArrayList<PartitionDesc>) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setPartDir(ArrayList<Path>) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setPartialScanAnalyzeCommand(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setPartialScanAnalyzeCommand(boolean) - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
setPartition(PTFInvocationSpec.PartitionSpec) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
setPartition(PTFInvocationSpec.PartitionSpec) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowSpec
 
setPartition(PartitionDef) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
setPartitionCols(ArrayList<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setPartitionCols(ArrayList<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setPartitionDescMap(Map<Map<String, PartitionDesc>, Map<String, PartitionDesc>>) - Method in class org.apache.hadoop.hive.ql.io.IOPrepareCache
 
setPartitionEval(VectorExpression[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator
 
setPartitioning(PTFInvocationSpec.PartitioningSpec) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionedTableFunctionSpec
 
setPartitioning(PTFInvocationSpec.PartitioningSpec) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowSpec
 
setPartitionName(String) - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult.PartitionResult
 
setPartitions(PrunedPartitionList) - Method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBOpPartitionWalkerCtx
Set partitions.
setPartitionsNotInMs(List<CheckResult.PartitionResult>) - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult
 
setPartitionsNotOnFs(List<CheckResult.PartitionResult>) - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult
 
setPartitionSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
setPartitionSpecs(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableExchangePartition
 
setPartKeySpec(FieldSchema) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableAlterPartDesc
 
setPartName(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setPartName(String) - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
setPartParams(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
setPartSpec(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.index.IndexMetadataChangeWork
 
setPartSpec(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.parse.AlterTablePartMergeFilesDesc
 
setPartSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
setPartSpec(PTFInvocationSpec.PartitionSpec) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitioningSpec
 
setPartSpec(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setPartSpec(LinkedHashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
setPartSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
setPartSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setPartSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
setPartSpec(LinkedHashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
setPartSpec(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
setPartSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
setPartSpec(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
setPartSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.TruncateTableDesc
 
setPartSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.UnlockTableDesc
 
setPartSpecForAlias(String, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
setPartSpecs(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
setPartSpecs(ArrayList<LinkedHashMap<String, String>>) - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
setPartSpecs(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
setPath(String) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock
 
setPathToAliases(HashMap<String, ArrayList<String>>) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
setPathToAliases(LinkedHashMap<String, ArrayList<String>>) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setPathToPartitionInfo(LinkedHashMap<String, PartitionDesc>) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setPattern(String) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.AbstractFilterStringColLikeStringScalar
 
setPattern(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
setPattern(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
setPattern(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
setPattern(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
setPctx(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.Optimizer
 
setPctx(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.PreCBOOptimizer
 
setPercent(Double) - Method in class org.apache.hadoop.hive.ql.parse.SplitSample
 
setpGraphContext(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
setPGraphContext(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.SkewJoinOptimizer.SkewJoinOptProcCtx
 
setpItr(PTFPartition.PTFPartitionIterator<Object>) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeadLag
 
setPivotResult(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
setPosBigTable(int) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setPosBigTable(int) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setPosition(int) - Method in class org.apache.hadoop.hive.ql.plan.ExplosionDesc
 
setPositive(boolean) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
setPosToAliasMap(Map<Integer, Set<String>>) - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
setPower(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerDoubleToDouble
 
setPower(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncPowerLongToDouble
 
setPredicate(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
setPredicateColumnsList(Set<String>) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setPreserved(boolean) - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
setPretty(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
setPrincipalDesc(List<PrincipalDesc>) - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
setPrincipalDesc(PrincipalDesc) - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
setPrincipals(List<PrincipalDesc>) - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
setPrincipals(List<PrincipalDesc>) - Method in class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
setPrincipalType(PrincipalType) - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
setPrincipalType(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
setPriv(PrivilegeType) - Method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
setPrivilege(Privilege) - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeDesc
 
setPrivileges(List<PrivilegeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
setPrivileges(List<PrivilegeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
setPrivilegeSubjectDesc(PrivilegeObjectDesc) - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
setPrivilegeSubjectDesc(PrivilegeObjectDesc) - Method in class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
SetProcessor - Class in org.apache.hadoop.hive.ql.processors
SetProcessor.
SetProcessor() - Constructor for class org.apache.hadoop.hive.ql.processors.SetProcessor
 
setProperties(Properties) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
setProperties(Properties) - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
setProperty(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setPropertyName(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowTblPropertiesDesc
 
setProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
setProps(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setProtectMode(ProtectMode) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
setProtectMode(ProtectMode) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setProtectModeEnable(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setProtectModeType(AlterTableDesc.ProtectModeType) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setPrunedPartitions(Map<String, PrunedPartitionList>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setQB(QB) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setQB(QB) - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
setQB(QB) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
setQBExpr1(QBExpr) - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
setQBExpr2(QBExpr) - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
setQbJoinTree(QBJoinTree) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setQBParseInfo(QBParseInfo) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setQuery(Query) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setQueryHasGroupBy(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setQueryHasMultipleTables(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setQueryId(String) - Method in class org.apache.hadoop.hive.ql.plan.LockDatabaseDesc
 
setQueryId(String) - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
setQueryId(String) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setQueryPartitions(Set<Partition>) - Method in class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
setQueryPlan(QueryPlan) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setQueryPlan(QueryPlan) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
setQueryProperties(QueryProperties) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setQueryProperty(String, HiveHistory.Keys, String) - Method in interface org.apache.hadoop.hive.ql.history.HiveHistory
Used to set query status and other attributes of a query
setQueryProperty(String, HiveHistory.Keys, String) - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
 
setQueryStartTime(Long) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setQueryStr(String) - Method in class org.apache.hadoop.hive.ql.plan.LockDatabaseDesc
 
setQueryStr(String) - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
setQueryString(String) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setQueryTasks(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
setQueued() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setQueueName(String) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
 
setRandom(Random) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRand
 
setRandom(Random) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRandNoSeed
 
setRawInputShape(ShapeDetails) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
setRealOutputFormatClassName(String) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
set a RealOutputFormatClassName corresponding to the HivePassThroughOutputFormat
setRecordLength(int) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
setRecordReader(RecordReader) - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
setReducer(Operator<?>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
SetReducerParallelism - Class in org.apache.hadoop.hive.ql.optimizer
SetReducerParallelism determines how many reducers should be run for a given reduce sink.
SetReducerParallelism() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SetReducerParallelism
 
setReduceSinkOperatorsAddedByEnforceBucketingSorting(List<ReduceSinkOperator>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setReduceWork(Configuration, ReduceWork) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
setReduceWork(Configuration, ReduceWork, Path, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
setReduceWork(ReduceWork) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
setRef(int, byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
Set a field by reference.
setRejectedJoinOps(Set<JoinOperator>) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
setRemovedReduceSinkBucketSort(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setRenamePartitionDesc(RenamePartitionDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setRepairPartitions(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
setReplace(boolean) - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
setReporter(Reporter) - Method in class org.apache.hadoop.hive.ql.exec.MapredContext
 
setReporter(Reporter) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setResDir(Path) - Method in class org.apache.hadoop.hive.ql.Context
 
setResFile(Path) - Method in class org.apache.hadoop.hive.ql.Context
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
setResFile(Path) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowColumnsDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowCreateTableDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowTblPropertiesDesc
 
setResidualPredicate(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.index.HiveIndexQueryContext
 
setResolver(ConditionalResolver) - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
setResolver(UDAFEvaluatorResolver) - Method in class org.apache.hadoop.hive.ql.exec.UDAF
Deprecated. Sets the resolver.
setResolver(UDFMethodResolver) - Method in class org.apache.hadoop.hive.ql.exec.UDF
Sets the resolver.
setResolverClassName(String) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
setResolverCtx(Object) - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
setResources(List<ResourceUri>) - Method in class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
setResult(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
setResult(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
setResult(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance.GenericUDAFVarianceEvaluator
 
setResultType(String) - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
setRetainList(Map<Byte, List<Integer>>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setRetainList(Map<Byte, List<Integer>>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setRetention(int) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setRetryCmdWhenFail(boolean) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setReturnValue(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.StringHelper
 
setReversedExprs(Map<String, Byte>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setReversedExprs(Map<String, Byte>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setRevokeDesc(RevokeDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setRight(int) - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
setRight(int) - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
setRightAliases(String[]) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setRoleDDLDesc(RoleDDLDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setRoleName(String) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveRoleGrant
 
setRoleOwnerName(String) - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
setRoles(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
setRootPath(Path) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setRootTask(boolean) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setRootTask(int, boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
setRootTasks(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setRootTasks(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
setRootTasks(ArrayList<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setRootTasks(ArrayList<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setRowCount(Integer) - Method in class org.apache.hadoop.hive.ql.parse.SplitSample
 
setRowId(long) - Method in class org.apache.hadoop.hive.ql.io.RecordIdentifier
 
setRowLimit(int) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setRowResolver(RowResolver) - Method in class org.apache.hadoop.hive.ql.parse.OpParseContext
 
setRowSchema(RowSchema) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
setRowSkewedIndex(List<SkewedColumnPositionPair>) - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
setRr(RowResolver) - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
setRslvMap(HashMap<String, LinkedHashMap<String, ColumnInfo>>) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
setRunning(boolean) - Method in class org.apache.hadoop.hive.ql.exec.TaskResult
 
setSampleDescr(FilterDesc.sampleDesc) - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
setSamplingType(int) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setSchema(RowSchema) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setSchema(MessageType, Configuration) - Static method in class org.apache.hadoop.hive.ql.io.parquet.write.DataWritableWriteSupport
 
setSchema(List<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setSchema(String) - Method in class org.apache.hadoop.hive.ql.plan.SchemaDesc
 
setScratchColumnMap(Map<String, Map<String, Integer>>) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setScratchColumnVectorTypes(Map<String, Map<Integer, String>>) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setScriptCmd(String) - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
setScriptErrInfo(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
setScriptInputInfo(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
setScriptOutputInfo(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
setSeedNum(int) - Method in class org.apache.hadoop.hive.ql.parse.SplitSample
 
setSeenFileSinkOps(List<FileSinkOperator>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setSelClauseColsFetchException(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setSelectColumnsList(Set<String>) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setSelectStar(boolean) - Method in class org.apache.hadoop.hive.ql.plan.SelectDesc
 
setSelExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setSelStarNoCompute(boolean) - Method in class org.apache.hadoop.hive.ql.plan.SelectDesc
 
setSerDe(SerDe, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
setSerde(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setSerde(SerDe) - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
setSerdeClassName(String) - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
setSerdeName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setSerdeParam(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setSerdeParams(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
setSerdeProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setSerdeProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setSerdeProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
setSerializationLib(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setSerializationLib(String) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
setSerializationNullFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setSerializationNullFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.ListSinkDesc
 
setSerName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setSessionState(SessionState) - Method in class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
setSessionState(SessionState) - Method in interface org.apache.hadoop.hive.ql.security.HiveAuthenticationProvider
This function is meant to be used only for hive internal implementations of this interface.
setSessionState(SessionState) - Method in class org.apache.hadoop.hive.ql.security.SessionStateConfigUserAuthenticator
 
setSessionState(SessionState) - Method in class org.apache.hadoop.hive.ql.security.SessionStateUserAuthenticator
 
setShowColumnsDesc(ShowColumnsDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowCompactionsDesc(ShowCompactionsDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowCreateTblDesc(ShowCreateTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowDatabasesDesc(ShowDatabasesDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowFuncsDesc(ShowFunctionsDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowGrantDesc(ShowGrantDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowIndexesDesc(ShowIndexesDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowLocksDesc(ShowLocksDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowPartsDesc(ShowPartitionsDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowTblPropertiesDesc(ShowTblPropertiesDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowTblsDesc(ShowTablesDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowTblStatusDesc(ShowTableStatusDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowTxnsDesc(ShowTxnsDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setSignature(ArrayList<ColumnInfo>) - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
setSink(ListSinkOperator) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setSkewColPosition(int) - Method in class org.apache.hadoop.hive.ql.plan.SkewedColumnPositionPair
 
setSkewedCol(boolean) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setSkewedCol(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
setSkewedColNames(List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setSkewedColNames(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setSkewedColNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setSkewedColNames(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
setSkewedColValues(List<List<String>>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setSkewedColValues(List<List<String>>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setSkewedColValues(ArrayList<List<String>>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setSkewedColValues(List<List<String>>) - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
setSkewedInfo(SkewedInfo) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setSkewedLocations(Map<List<String>, String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setSkewedValueLocationMap(List<String>, String) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
setSkewedValueLocationMap(List<String>, String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setSkewedValuesDirNames(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
setSkewJoinJobCounter(LongWritable) - Method in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
setSkewKeyDefinition(int) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setSkewKeyDefinition(int) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
set skew key definition.
setSkewKeysValuesTables(Map<Byte, TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setSkewKeysValuesTables(Map<Byte, TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setSmallKeysDirMap(Map<Byte, Map<Byte, Path>>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setSmallKeysDirMap(Map<Byte, Map<Byte, Path>>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
set the mapping from tbl to dir for small keys.
setSmbMapJoinContext(Map<SMBMapJoinOperator, QBJoinTree>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setSortByExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
Set the Sort By AST for the clause.
setSortCols(List<Order>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setSortCols(List<Order>) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc.OnePartitionDesc
 
setSortCols(ArrayList<Order>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setSortColumns(ArrayList<Order>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setSortedCols(Operator<? extends OperatorDesc>, List<BucketingSortingCtx.SortCol>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx
 
setSortedColsByDirectory(Map<String, List<BucketingSortingCtx.SortCol>>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx
 
setSortedExpr(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
setSortedFilter(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
setSource(String) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFQueryInputSpec
 
setSource(Operator<?>) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setSourceDirs(List<Path>) - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
setSourceId(String) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowSpec
 
setSourceTable(Table) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableExchangePartition
 
setSourceTask(Task) - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
setSPColNames(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
setSplitNum(int) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
setSplitSample(SplitSample) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setSPPath(String) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setSrcForAlias(String, Table) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
setSrcForAlias(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setSrcs(String[]) - Method in class org.apache.hadoop.hive.ql.optimizer.SortBucketJoinProcCtx
 
setStackTraces(Map<String, List<List<String>>>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setStageID(String) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
setStar(boolean) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFunctionSpec
 
setStar(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
setStart(WindowingSpec.BoundarySpec) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFrameSpec
 
setStart(BoundaryDef) - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFrameDef
 
setStarted() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setStarted() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setStartIdx(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStart
 
setStartIdx(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStartLen
 
setStaticSpec(String) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setStatistics(Statistics) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setStatistics(Statistics) - Method in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
setStatistics(Statistics) - Method in interface org.apache.hadoop.hive.ql.plan.OperatorDesc
 
setStatsAggPrefix(String) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
Set the stats aggregation key.
setStatsAggPrefix(String) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setStatsCollectRawDataSize(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setStatsReliable(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setStatsReliable(boolean) - Method in class org.apache.hadoop.hive.ql.plan.StatsNoJobWork
 
setStatsReliable(boolean) - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
setStatsReliable(boolean) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setStorageHandler(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setStorageHandler(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setStorageHandler(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setStoredAsSubDirectories(boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setStoredAsSubDirectories(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setStoredAsSubDirectories(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setStoredAsSubDirectories(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ListBucketingCtx
 
setStreamAliases(List<String>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setStringValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
setStringValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
setStringValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
setStructFieldData(Object, StructField, Object) - Method in class org.apache.hadoop.hive.ql.io.parquet.serde.ArrayWritableObjectInspector
 
setSubqAlias(String, QBExpr) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
setSwitchDatabaseDesc(SwitchDatabaseDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
Set Switch Database descriptor
setT(Table) - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
setTabAlias(String) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setTabAlias(LineageInfo.TableAliasInfo) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.BaseColumnInfo
 
setTabAlias(String) - Method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBExprProcCtx
 
setTabAlias(String) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcCtx
 
setTabAlias(String) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprPrunerInfo
 
setTabAlias(String, String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setTabAlias(String) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
setTable(Table) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.TableAliasInfo
 
setTable(Table) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
Should be only used by serialization.
setTable(Table) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setTable(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
setTable(boolean) - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
setTableAccessInfo(TableAccessInfo) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Sets the table access information.
setTableAccessInfo(TableAccessInfo) - Method in class org.apache.hadoop.hive.ql.QueryPlan
Sets the table access information.
setTableAlias(String) - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
setTableDef(PartitionedTableFunctionDef) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
setTableDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
setTableDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
setTableDesc(CreateTableDesc) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setTableDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
setTableInfo(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult.PartitionResult
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.parse.AlterTablePartMergeFilesDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableAlterPartDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.DropIndexDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.RenamePartitionDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowColumnsDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowCreateTableDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowTblPropertiesDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.TruncateTableDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.UnlockTableDesc
 
setTablesNotInMs(List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult
 
setTablesNotOnFs(List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult
 
setTableType(TableType) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
SettableUDF - Interface in org.apache.hadoop.hive.ql.udf
THIS INTERFACE IS UNSTABLE AND SHOULD NOT BE USED BY 3RD PARTY UDFS.
setTabName(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
setTabProps(String, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setTabSample(String, TableSample) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setTag(int) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setTagOrder(Byte[]) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setTagOrder(Byte[]) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
The order in which tables should be processed when joining.
setTagToAlias(HashMap<Byte, String>) - Method in class org.apache.hadoop.hive.ql.plan.SMBJoinDesc
 
setTagToInput(Map<Integer, String>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
setTagToValueDesc(List<TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceWork
 
setTargetDir(Path) - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
setTargetDirs(List<Path>) - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
setTaskCounters(String, String, Counters) - Method in interface org.apache.hadoop.hive.ql.history.HiveHistory
Serialize the task counters and set as a task property.
setTaskCounters(String, String, Counters) - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
 
setTaskPlan(String, Operator<? extends OperatorDesc>, Task<?>, boolean, GenMRProcContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
set the current task in the mapredWork.
setTaskPlan(String, Operator<? extends OperatorDesc>, Task<?>, boolean, GenMRProcContext, PrunedPartitionList) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
set the current task in the mapredWork.
setTaskPlan(String, String, Operator<? extends OperatorDesc>, MapWork, boolean, TableDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
set the current task in the mapredWork.
setTaskProperty(String, String, HiveHistory.Keys, String) - Method in interface org.apache.hadoop.hive.ql.history.HiveHistory
Used to set task properties.
setTaskProperty(String, String, HiveHistory.Keys, String) - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
 
setTaskTag(int) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setTaskToAliases(HashMap<Task<? extends Serializable>, Set<String>>) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
setTbl(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.HashTableDummyDesc
 
setTblAliasToBucketedFilePathsInEachPartition(Map<String, List<List<String>>>) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
setTblAliasToNumberOfBucketsInEachPartition(Map<String, List<Integer>>) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketJoinProcCtx
 
setTblColPosition(int) - Method in class org.apache.hadoop.hive.ql.plan.SkewedColumnPositionPair
 
setTblDataDone(boolean) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
setTblDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setTblDir(Path) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setTblLevel(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsDesc
 
setTblLvl(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setTblProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setTblProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setTblProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setTblProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setTemp(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
setTemp(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DropFunctionDesc
 
setTezSession(TezSessionState) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setTFunction(TableFunctionEvaluator) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
setTmpHDFSPath(Path) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setTmpOutputFile(File) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setTmpPath(Path) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
setTokenRewriteStream(TokenRewriteStream) - Method in class org.apache.hadoop.hive.ql.Context
Set the token rewrite stream being used to parse the current top-level SQL statement.
setTopN(int) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setTopNMemoryUsage(float) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setTopOps(HashMap<String, Operator<? extends OperatorDesc>>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setTopSelOps(HashMap<String, Operator<? extends OperatorDesc>>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setTopToProps(HashMap<TableScanOperator, Map<String, String>>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setTopToTable(HashMap<TableScanOperator, Table>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setTotalFiles(int) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setTotalLength(Long) - Method in class org.apache.hadoop.hive.ql.parse.SplitSample
 
setTPartition(Partition) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
Should be only used by serialization.
setTransformsRawInput(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PartitionedTableFunctionDef
 
setTransformsRawInput(boolean) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
setTruncateTblDesc(TruncateTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setTryCount(int) - Method in class org.apache.hadoop.hive.ql.Context
 
setTryCount(int) - Method in class org.apache.hadoop.hive.ql.Driver
 
setTTable(Table) - Method in class org.apache.hadoop.hive.ql.metadata.Table
This function should only be called by Java serialization.
setTurnOffSkewed(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setTyp(Entity.Type) - Method in class org.apache.hadoop.hive.ql.hooks.Entity
 
setType(TypeInfo) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setType(ConstantVectorExpression.Type) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
setType(String) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.IdentityExpression
 
setType(LineageInfo.DependencyType) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
setType(PTFInvocationSpec.PTFQueryInputType) - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFQueryInputSpec
 
setType(AlterTableDesc.AlterTableTypes) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
setType(ArchiveWork.ArchiveActionType) - Method in class org.apache.hadoop.hive.ql.plan.ArchiveWork
 
setType(int) - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
setType(PrincipalType) - Method in class org.apache.hadoop.hive.ql.plan.PrincipalDesc
 
setType(PTFInvocationSpec.PTFQueryInputType) - Method in class org.apache.hadoop.hive.ql.plan.ptf.PTFQueryInputDef
 
setTypeCheckCtx(TypeCheckCtx) - Method in class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
setTypeInfo(PrimitiveTypeInfo) - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
setTypeInfo(TypeInfo) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnListDesc
 
setTypeInfo(TypeInfo) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
setTypeInfo(TypeInfo) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToChar
Provide char type parameters for the output object inspector.
setTypeInfo(DecimalTypeInfo) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToDecimal
 
setTypeInfo(TypeInfo) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToDecimal
 
setTypeInfo(TypeInfo) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFToVarchar
Provide varchar type parameters for the output object inspector.
setTypeInfo(TypeInfo) - Method in interface org.apache.hadoop.hive.ql.udf.SettableUDF
Add data to UDF prior to initialization.
setTypeName(String) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setTypeString(String) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression
 
setUCtx(UnionProcContext) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setUdafEvaluator(Class<? extends UDAFEvaluator>) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
setUdfClassName(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
setUdfName(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
setUgi(UserGroupInformation) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
setUnionParseContext(UnionOperator, UnionProcContext.UnionParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext
 
setUnionTask(UnionOperator, GenMRProcContext.GenMRUnionCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setUnlockDatabaseDesc(UnlockDatabaseDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setUnlockTblDesc(UnlockTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setUnparseTranslator(UnparseTranslator) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
setupContext(List<Path>) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
used for bucket map join
setupOutputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.Noop.NoopResolver
 
setupOutputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMap.NoopWithMapResolver
 
setupOutputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
 
setupOutputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.WindowingTableFunctionResolver
 
setupPartitionOutputOI(SerDe, StructObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
setupPool(HiveConf) - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
setupRawInputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMap.NoopWithMapResolver
 
setupRawInputOI() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
 
setUseBucketizedHiveInputFormat(boolean) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setUseBucketizedHiveInputFormat(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setUserName(String) - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContext
 
setUserName(String) - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
setUseSorted(boolean) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setUsesScript(boolean) - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
setVal(int, byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
Set a field by actually copying in to a local buffer.
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColAndScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterColOrScalar
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarAndColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.FilterScalarOrColumn
 
setValue(long) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongColDivideLongScalar
 
setValue(double) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarDivideLongColumn
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColScalar
 
setValue(byte[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatScalarCol
 
setValue(Object, ColumnVector, int) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriter
 
setValue(Object) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
setValueBuffer(RCFile.ValueBuffer) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileValueBufferWrapper
 
setValueCols(ArrayList<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setValueEval(VectorExpression[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator
 
setValueFilteredTblDescs(List<TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setValues(long, int, long) - Method in class org.apache.hadoop.hive.ql.io.RecordIdentifier
Set the identifier.
setValues(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
Set Partition's values
setValueSerializeInfo(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setValuesSerializeInfos(List<TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.DemuxDesc
 
setValueTblDescs(List<TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setValueTblDescs(List<TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setValueTblFilteredDescs(List<TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setValueWriters(VectorExpressionWriter[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
setVariable(int) - Method in class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
Set this argument to be a "variable" one which is to be taken from a specified column vector number i.
setVectorMode(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc
 
setVectorMode(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapWork
 
setVersionAndIndex(int, int) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferRow
accessor for VectorAggregationBufferBatch to set its caching info on this set.
setvExpressions(VectorExpression[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator
 
setVExpressions(VectorExpression[]) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator
 
setViewExpandedText(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setViewExpandedText(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setViewName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setViewOriginalText(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setViewOriginalText(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setVirtualCol(boolean) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setVirtualCols(List<VirtualColumn>) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setWdwProcessingOutputOI(StructObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.WindowingTableFunctionResolver
 
setWFnEval(GenericUDAFEvaluator) - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
setWhrClauseColsFetchException(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteCanApplyCtx
 
setWhrExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setWindowExpressions(ArrayList<WindowingSpec.WindowExpressionSpec>) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec
 
setWindowFrame(WindowingSpec.WindowFrameSpec) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowSpec
 
setWindowFrame(WindowFrameDef) - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
setWindowFunctions(List<WindowFunctionDef>) - Method in class org.apache.hadoop.hive.ql.plan.ptf.WindowTableFunctionDef
 
setWindowSpec(WindowingSpec.WindowSpec) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFunctionSpec
 
setWindowSpecs(HashMap<String, WindowingSpec.WindowSpec>) - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec
 
setWork(FetchWork) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
setWork(T) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setWorkflowAdjacencies(Configuration, QueryPlan) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
ShapeDetails - Class in org.apache.hadoop.hive.ql.plan.ptf
 
ShapeDetails() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.ShapeDetails
 
shouldEndBinarySearch() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
showColumns(Hive, ShowColumnsDesc) - Method in class org.apache.hadoop.hive.ql.exec.DDLTask
 
ShowColumnsDesc - Class in org.apache.hadoop.hive.ql.plan
 
ShowColumnsDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowColumnsDesc
 
ShowColumnsDesc(Path) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowColumnsDesc
 
ShowColumnsDesc(Path, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowColumnsDesc
 
ShowColumnsDesc(Path, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowColumnsDesc
 
showCompactions() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
ShowCompactionsDesc - Class in org.apache.hadoop.hive.ql.plan
Descriptor for showing compactions.
ShowCompactionsDesc(Path) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowCompactionsDesc
 
ShowCompactionsDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowCompactionsDesc
No arg constructor for serialization.
ShowCreateTableDesc - Class in org.apache.hadoop.hive.ql.plan
ShowCreateTableDesc.
ShowCreateTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowCreateTableDesc
For serialization use only.
ShowCreateTableDesc(String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowCreateTableDesc
 
showDatabaseDescription(DataOutputStream, String, String, String, String, String, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.metadata.formatting.JsonMetaDataFormatter
Show the description of a database
showDatabaseDescription(DataOutputStream, String, String, String, String, String, Map<String, String>) - Method in interface org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatter
Describe a database.
showDatabases(DataOutputStream, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.formatting.JsonMetaDataFormatter
Show a list of databases
showDatabases(DataOutputStream, List<String>) - Method in interface org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatter
Show the databases
ShowDatabasesDesc - Class in org.apache.hadoop.hive.ql.plan
ShowDatabasesDesc.
ShowDatabasesDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
ShowDatabasesDesc(Path) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
ShowDatabasesDesc(Path, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
ShowFunctionsDesc - Class in org.apache.hadoop.hive.ql.plan
ShowFunctionsDesc.
ShowFunctionsDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
ShowFunctionsDesc(Path) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
ShowFunctionsDesc(Path, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
ShowGrantDesc - Class in org.apache.hadoop.hive.ql.plan
 
ShowGrantDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
ShowGrantDesc(String, PrincipalDesc, PrivilegeObjectDesc, List<String>) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
ShowIndexesDesc - Class in org.apache.hadoop.hive.ql.plan
ShowIndexesDesc.
ShowIndexesDesc(String, Path) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowIndexesDesc
 
ShowLocksDesc - Class in org.apache.hadoop.hive.ql.plan
ShowLocksDesc.
ShowLocksDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
ShowLocksDesc(Path, String, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
ShowLocksDesc(Path, String, HashMap<String, String>, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
ShowPartitionsDesc - Class in org.apache.hadoop.hive.ql.plan
ShowPartitionsDesc.
ShowPartitionsDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
ShowPartitionsDesc(String, Path, Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
showPrivilegeGrant(HiveObjectType, String, PrincipalType, String, String, List<String>, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
showPrivileges(HivePrincipal, HivePrivilegeObject) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAccessController
 
showPrivileges(HivePrincipal, HivePrivilegeObject) - Method in interface org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer
Show privileges for given principal on given object
showPrivileges(HivePrincipal, HivePrivilegeObject) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl
 
showPrivileges(HivePrincipal, HivePrivilegeObject) - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
showTablePartitons(DataOutputStream, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.formatting.JsonMetaDataFormatter
Show the table partitions.
showTablePartitons(DataOutputStream, List<String>) - Method in interface org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatter
Show the table partitions.
showTables(DataOutputStream, Set<String>) - Method in class org.apache.hadoop.hive.ql.metadata.formatting.JsonMetaDataFormatter
Show a list of tables.
showTables(DataOutputStream, Set<String>) - Method in interface org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatter
Show a list of tables.
ShowTablesDesc - Class in org.apache.hadoop.hive.ql.plan
ShowTablesDesc.
ShowTablesDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
ShowTablesDesc(Path) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
ShowTablesDesc(Path, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
ShowTablesDesc(Path, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
showTableStatus(DataOutputStream, Hive, HiveConf, List<Table>, Map<String, String>, Partition) - Method in class org.apache.hadoop.hive.ql.metadata.formatting.JsonMetaDataFormatter
 
showTableStatus(DataOutputStream, Hive, HiveConf, List<Table>, Map<String, String>, Partition) - Method in interface org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatter
Show the table status.
ShowTableStatusDesc - Class in org.apache.hadoop.hive.ql.plan
ShowTableStatusDesc.
ShowTableStatusDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
For serializatino use only.
ShowTableStatusDesc(String, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
ShowTableStatusDesc(String, String, String, HashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
ShowTblPropertiesDesc - Class in org.apache.hadoop.hive.ql.plan
ShowTblPropertiesDesc.
ShowTblPropertiesDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTblPropertiesDesc
For serialization use only.
ShowTblPropertiesDesc(String, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTblPropertiesDesc
 
showTime(long) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
showTransactions() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
ShowTxnsDesc - Class in org.apache.hadoop.hive.ql.plan
Descriptor for showing transactions.
ShowTxnsDesc(Path) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTxnsDesc
 
ShowTxnsDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTxnsDesc
No arg constructor for serialization.
shrinkSplit(long) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
shutdown() - Method in class org.apache.hadoop.hive.ql.DriverContext
Cleans up remaining tasks in case of failure
shutdown() - Method in class org.apache.hadoop.hive.ql.exec.mr.ExecDriver
 
shutdown() - Method in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
shutdown() - Method in class org.apache.hadoop.hive.ql.exec.mr.MapRedTask
 
shutdown() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
sign(int, Decimal128, LongColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
sign(double) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
sign(long) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
SimpleFetchAggregation - Class in org.apache.hadoop.hive.ql.optimizer
 
SimpleFetchAggregation() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SimpleFetchAggregation
 
SimpleFetchOptimizer - Class in org.apache.hadoop.hive.ql.optimizer
Tries to convert simple fetch query to single fetch task, which fetches rows directly from location of table/partition.
SimpleFetchOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SimpleFetchOptimizer
 
SimpleGenericUDAFParameterInfo - Class in org.apache.hadoop.hive.ql.udf.generic
A simple implementation of GenericUDAFParameterInfo.
SimpleGenericUDAFParameterInfo(ObjectInspector[], boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.SimpleGenericUDAFParameterInfo
 
size() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
size() - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
size() - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainer
 
size() - Method in class org.apache.hadoop.hive.ql.exec.PTFPartition
 
size - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
size() - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Returns the number of n-grams in our buffer.
size() - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.SameList
 
SizeBasedBigTableSelectorForAutoSMJ - Class in org.apache.hadoop.hive.ql.optimizer
 
SizeBasedBigTableSelectorForAutoSMJ() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SizeBasedBigTableSelectorForAutoSMJ
 
sizeLeft - Variable in class org.apache.hadoop.hive.ql.optimizer.SamplePruner.AddPathReturnStatus
 
SkewedColumnPositionPair - Class in org.apache.hadoop.hive.ql.plan
This class record 2 types of positions for a skewed column: 1.
SkewedColumnPositionPair() - Constructor for class org.apache.hadoop.hive.ql.plan.SkewedColumnPositionPair
 
SkewedColumnPositionPair(int, int) - Constructor for class org.apache.hadoop.hive.ql.plan.SkewedColumnPositionPair
 
skewJoinEnabled(HiveConf, JoinOperator) - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.GenMRSkewJoinProcessor
 
SkewJoinHandler - Class in org.apache.hadoop.hive.ql.exec
At runtime in Join, we output big keys in one table into one corresponding directories, and all same keys in other tables into different dirs(one for each table).
SkewJoinHandler(CommonJoinOperator<? extends OperatorDesc>) - Constructor for class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
SkewJoinOptimizer - Class in org.apache.hadoop.hive.ql.optimizer
SkewJoinOptimizer.
SkewJoinOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SkewJoinOptimizer
 
SkewJoinOptimizer.SkewJoinOptProcCtx - Class in org.apache.hadoop.hive.ql.optimizer
SkewJoinOptProcCtx.
SkewJoinOptimizer.SkewJoinOptProcCtx(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.SkewJoinOptimizer.SkewJoinOptProcCtx
 
SkewJoinOptimizer.SkewJoinProc - Class in org.apache.hadoop.hive.ql.optimizer
 
SkewJoinOptimizer.SkewJoinProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SkewJoinOptimizer.SkewJoinProc
 
SkewJoinProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.physical
Node processor factory for skew join resolver.
SkewJoinProcFactory.SkewJoinDefaultProcessor - Class in org.apache.hadoop.hive.ql.optimizer.physical
SkewJoinDefaultProcessor.
SkewJoinProcFactory.SkewJoinDefaultProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinProcFactory.SkewJoinDefaultProcessor
 
SkewJoinProcFactory.SkewJoinJoinProcessor - Class in org.apache.hadoop.hive.ql.optimizer.physical
SkewJoinJoinProcessor.
SkewJoinProcFactory.SkewJoinJoinProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinProcFactory.SkewJoinJoinProcessor
 
SkewJoinResolver - Class in org.apache.hadoop.hive.ql.optimizer.physical
An implementation of PhysicalPlanResolver.
SkewJoinResolver() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinResolver
 
SkewJoinResolver.SkewJoinProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.physical
A container of current task and parse context.
SkewJoinResolver.SkewJoinProcCtx(Task<? extends Serializable>, ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinResolver.SkewJoinProcCtx
 
skip(long) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
skip(long) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
skipBytes(int) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectInput
 
skipBytes(int) - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Skips count number of bytes in this stream.
skipHeader(RecordReader<WritableComparable, Writable>, int, WritableComparable, Writable) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Skip header lines in the table file when reading the record.
skipSkewedDirectory(Boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPrunerUtils
Decide if pruner skips the skewed directory Input: if the skewed value matches the expression tree Ouput: if pruner should skip the directory represented by the skewed value If match result is unknown(null) or true, pruner doesn't skip the directory If match result is false, pruner skips the dir.
SMBJoinDesc - Class in org.apache.hadoop.hive.ql.plan
 
SMBJoinDesc(MapJoinDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.SMBJoinDesc
 
SMBJoinDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.SMBJoinDesc
 
SMBMapJoinOperator - Class in org.apache.hadoop.hive.ql.exec
Sorted Merge Map Join Operator.
SMBMapJoinOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
SMBMapJoinOperator(AbstractMapJoinOperator<? extends MapJoinDesc>) - Constructor for class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
SortBucketJoinProcCtx - Class in org.apache.hadoop.hive.ql.optimizer
 
SortBucketJoinProcCtx(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.optimizer.SortBucketJoinProcCtx
 
SortedDynPartitionOptimizer - Class in org.apache.hadoop.hive.ql.optimizer
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.
SortedDynPartitionOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SortedDynPartitionOptimizer
 
SortedMergeBucketMapJoinOptimizer - Class in org.apache.hadoop.hive.ql.optimizer
 
SortedMergeBucketMapJoinOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SortedMergeBucketMapJoinOptimizer
 
SortedMergeBucketMapjoinProc - Class in org.apache.hadoop.hive.ql.optimizer
 
SortedMergeBucketMapjoinProc(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.SortedMergeBucketMapjoinProc
 
SortedMergeBucketMapjoinProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SortedMergeBucketMapjoinProc
 
SortedMergeJoinProc - Class in org.apache.hadoop.hive.ql.optimizer
 
SortedMergeJoinProc(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.SortedMergeJoinProc
 
SortedMergeJoinProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SortedMergeJoinProc
 
sortFieldSchemas(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
SortMergeJoinResolver - Class in org.apache.hadoop.hive.ql.optimizer.physical
 
SortMergeJoinResolver() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.SortMergeJoinResolver
 
SortMergeJoinTaskDispatcher - Class in org.apache.hadoop.hive.ql.optimizer.physical
Iterator over each task.
SortMergeJoinTaskDispatcher(PhysicalContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.SortMergeJoinTaskDispatcher
 
SOURCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.optiq.stats.HiveRelMdDistinctRowCount
 
SOURCE - Static variable in class org.apache.hadoop.hive.ql.optimizer.optiq.stats.HiveRelMdSelectivity
 
specType - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
split(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
split predicates by AND op
split(ExprNodeDesc, List<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils
split predicates by AND op
splitArgs(String) - Static method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
splitQualifiedFunctionName(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionUtils
Splits a qualified function name into an array containing the database name and function name.
SplitSample - Class in org.apache.hadoop.hive.ql.parse
This class stores all the information specified in the TABLESAMPLE(...) clause.
SplitSample() - Constructor for class org.apache.hadoop.hive.ql.parse.SplitSample
 
SplitSample(double, int) - Constructor for class org.apache.hadoop.hive.ql.parse.SplitSample
 
SplitSample(long, int) - Constructor for class org.apache.hadoop.hive.ql.parse.SplitSample
 
SplitSample(int) - Constructor for class org.apache.hadoop.hive.ql.parse.SplitSample
 
SQLAuthorizationUtils - Class in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
 
SQLAuthorizationUtils() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLAuthorizationUtils
 
sqlEscapeChar - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
SqlFunctionConverter - Class in org.apache.hadoop.hive.ql.optimizer.optiq.translator
 
SqlFunctionConverter() - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.translator.SqlFunctionConverter
 
SQLPrivilegeType - Enum in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
 
SQLPrivTypeGrant - Enum in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
 
SQLStdHiveAccessController - Class in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
Implements functionality of access control statements for sql standard based authorization
SQLStdHiveAccessController(HiveMetastoreClientFactory, HiveConf, HiveAuthenticationProvider) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController
 
SQLStdHiveAuthorizationValidator - Class in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
 
SQLStdHiveAuthorizationValidator(HiveMetastoreClientFactory, HiveConf, HiveAuthenticationProvider, SQLStdHiveAccessController) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAuthorizationValidator
 
SQLStdHiveAuthorizerFactory - Class in org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd
 
SQLStdHiveAuthorizerFactory() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAuthorizerFactory
 
StageIDsRearranger - Class in org.apache.hadoop.hive.ql.optimizer.physical
Simple renumbering of stage ids
StageIDsRearranger() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.StageIDsRearranger
 
StageIDsRearranger.TaskTraverse - Class in org.apache.hadoop.hive.ql.optimizer.physical
 
StageIDsRearranger.TaskTraverse() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.StageIDsRearranger.TaskTraverse
 
StandardParquetHiveMapInspector - Class in org.apache.hadoop.hive.ql.io.parquet.serde
The StandardParquetHiveMapInspector will inspect an ArrayWritable, considering it as a Hive map.
It can also inspect a Map if Hive decides to inspect the result of an inspection.
StandardParquetHiveMapInspector(ObjectInspector, ObjectInspector) - Constructor for class org.apache.hadoop.hive.ql.io.parquet.serde.StandardParquetHiveMapInspector
 
start - Variable in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
 
start() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.ArrayWritableGroupConverter
 
start() - Method in class org.apache.hadoop.hive.ql.io.parquet.convert.DataWritableGroupConverter
 
start(HiveConf) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
start a new session and set it to current session.
start(SessionState) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
set current session to existing session object if a thread is running multiple sessions - it must call this method with the new session object when switching from one session to another.
startAnd() - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Builder
Start building an and operation and push it on the stack.
startBatch() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferBatch
resets the internal aggregation buffers sets index and increments the versioning used to optimize the selection vector population.
started() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
startForward(String) - Method in class org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask
 
startGroup() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
startGroup() - Method in class org.apache.hadoop.hive.ql.exec.DemuxOperator
 
startGroup() - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
startGroup() - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
startGroup() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
startGroup() - Method in class org.apache.hadoop.hive.ql.exec.MuxOperator
 
startGroup() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
startNot() - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Builder
Start building a not operation and push it on the stack.
startOr() - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument.Builder
Start building an or operation and push it on the stack.
startPool() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
startQuery(String, String) - Method in interface org.apache.hadoop.hive.ql.history.HiveHistory
Called at the start of query execution in Driver.execute().
startQuery(String, String) - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
 
startTask(String, Task<? extends Serializable>, String) - Method in interface org.apache.hadoop.hive.ql.history.HiveHistory
Called at the start of a task.
startTask(String, Task<? extends Serializable>, String) - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryImpl
 
startVectorizedBatch(int) - Method in class org.apache.hadoop.hive.ql.exec.TopNHash
Perform basic checks and initialize TopNHash for the new vectorized row batch.
startWalking(Collection<Node>, HashMap<Node, Object>) - Method in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
starting point for walking.
startWalking(Collection<Node>, HashMap<Node, Object>) - Method in interface org.apache.hadoop.hive.ql.lib.GraphWalker
starting point for walking.
startWalking(Collection<Node>, HashMap<Node, Object>) - Method in class org.apache.hadoop.hive.ql.lib.TaskGraphWalker
starting point for walking.
startWalking(Collection<Node>, HashMap<Node, Object>) - Method in class org.apache.hadoop.hive.ql.parse.GenTezWorkWalker
starting point for walking.
Stat - Class in org.apache.hadoop.hive.ql.exec
 
Stat() - Constructor for class org.apache.hadoop.hive.ql.exec.Stat
 
Statistics - Class in org.apache.hadoop.hive.ql.plan
Statistics.
Statistics() - Constructor for class org.apache.hadoop.hive.ql.plan.Statistics
 
Statistics(long, long) - Constructor for class org.apache.hadoop.hive.ql.plan.Statistics
 
Statistics.State - Enum in org.apache.hadoop.hive.ql.plan
 
StatsAggregator - Interface in org.apache.hadoop.hive.ql.stats
An interface for any possible implementation for gathering statistics.
StatsCollectionTaskIndependent - Interface in org.apache.hadoop.hive.ql.stats
This is just a marker interface to differentiate between stats publisher / aggregator which don't track stats per task, as oppose to others which do.
StatsFactory - Class in org.apache.hadoop.hive.ql.stats
A factory of stats publisher and aggregator implementations of the StatsPublisher and StatsAggregator interfaces.
StatsNoJobTask - Class in org.apache.hadoop.hive.ql.exec
StatsNoJobTask is used in cases where stats collection is the only task for the given query (no parent MR or Tez job).
StatsNoJobTask() - Constructor for class org.apache.hadoop.hive.ql.exec.StatsNoJobTask
 
StatsNoJobWork - Class in org.apache.hadoop.hive.ql.plan
Client-side stats aggregator task.
StatsNoJobWork() - Constructor for class org.apache.hadoop.hive.ql.plan.StatsNoJobWork
 
StatsNoJobWork(BaseSemanticAnalyzer.tableSpec) - Constructor for class org.apache.hadoop.hive.ql.plan.StatsNoJobWork
 
StatsNoJobWork(boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.StatsNoJobWork
 
StatsOptimizer - Class in org.apache.hadoop.hive.ql.optimizer
There is a set of queries which can be answered entirely from statistics stored in metastore.
StatsOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.StatsOptimizer
 
StatsProvidingRecordReader - Interface in org.apache.hadoop.hive.ql.io
If a file format internally gathers statistics (like ORC) then it can expose the statistics through this interface.
StatsProvidingRecordWriter - Interface in org.apache.hadoop.hive.ql.io
If a file format internally gathers statistics (like ORC) while writing then it can expose the statistics through this record writer interface.
StatsPublisher - Interface in org.apache.hadoop.hive.ql.stats
An interface for any possible implementation for publishing statics.
StatsRulesProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.stats.annotation
 
StatsRulesProcFactory() - Constructor for class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory
 
StatsRulesProcFactory.DefaultStatsRule - Class in org.apache.hadoop.hive.ql.optimizer.stats.annotation
Default rule is to aggregate the statistics from all its parent operators.
StatsRulesProcFactory.DefaultStatsRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory.DefaultStatsRule
 
StatsRulesProcFactory.FilterStatsRule - Class in org.apache.hadoop.hive.ql.optimizer.stats.annotation
FILTER operator does not change the average row size but it does change the number of rows emitted.
StatsRulesProcFactory.FilterStatsRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory.FilterStatsRule
 
StatsRulesProcFactory.GroupByStatsRule - Class in org.apache.hadoop.hive.ql.optimizer.stats.annotation
GROUPBY operator changes the number of rows.
StatsRulesProcFactory.GroupByStatsRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory.GroupByStatsRule
 
StatsRulesProcFactory.JoinStatsRule - Class in org.apache.hadoop.hive.ql.optimizer.stats.annotation
JOIN operator can yield any of the following three cases The values of join keys are disjoint in both relations in which case T(RXS) = 0 (we need histograms for this) Join key is primary key on relation R and foreign key on relation S in which case every tuple in S will have a tuple in R T(RXS) = T(S) (we need histograms for this) Both R & S relation have same value for join-key.
StatsRulesProcFactory.JoinStatsRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory.JoinStatsRule
 
StatsRulesProcFactory.LimitStatsRule - Class in org.apache.hadoop.hive.ql.optimizer.stats.annotation
LIMIT operator changes the number of rows and thereby the data size.
StatsRulesProcFactory.LimitStatsRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory.LimitStatsRule
 
StatsRulesProcFactory.SelectStatsRule - Class in org.apache.hadoop.hive.ql.optimizer.stats.annotation
SELECT operator doesn't change the number of rows emitted from the parent operator.
StatsRulesProcFactory.SelectStatsRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory.SelectStatsRule
 
StatsRulesProcFactory.TableScanStatsRule - Class in org.apache.hadoop.hive.ql.optimizer.stats.annotation
Collect basic statistics like number of rows, data size and column level statistics from the table.
StatsRulesProcFactory.TableScanStatsRule() - Constructor for class org.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactory.TableScanStatsRule
 
StatsTask - Class in org.apache.hadoop.hive.ql.exec
StatsTask implementation.
StatsTask() - Constructor for class org.apache.hadoop.hive.ql.exec.StatsTask
 
StatsUtils - Class in org.apache.hadoop.hive.ql.stats
 
StatsUtils() - Constructor for class org.apache.hadoop.hive.ql.stats.StatsUtils
 
StatsWork - Class in org.apache.hadoop.hive.ql.plan
ConditionalStats.
StatsWork() - Constructor for class org.apache.hadoop.hive.ql.plan.StatsWork
 
StatsWork(BaseSemanticAnalyzer.tableSpec) - Constructor for class org.apache.hadoop.hive.ql.plan.StatsWork
 
StatsWork(LoadTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.StatsWork
 
StatsWork(LoadFileDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.StatsWork
 
StatsWork(boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.StatsWork
 
stop() - Method in class org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager
 
StorageBasedAuthorizationProvider - Class in org.apache.hadoop.hive.ql.security.authorization
StorageBasedAuthorizationProvider is an implementation of HiveMetastoreAuthorizationProvider that tries to look at the hdfs permissions of files and directories associated with objects like databases, tables and partitions to determine whether or not an operation is allowed.
StorageBasedAuthorizationProvider() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider
 
storeValue(int, BytesWritable, int, boolean) - Method in class org.apache.hadoop.hive.ql.exec.TopNHash
Stores the value for the key in the heap.
StringColumnInList - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Evaluate an IN boolean expression (not a filter) on a batch for a vector of strings.
StringColumnInList() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringColumnInList
 
StringColumnInList(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringColumnInList
After construction you must call setInListValues() to add the values to the IN set.
StringColumnStatistics - Interface in org.apache.hadoop.hive.ql.io.orc
Statistics for string columns.
StringConcatColCol - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Vectorized instruction to concatenate two string columns and put the output in a third column.
StringConcatColCol(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColCol
 
StringConcatColCol() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColCol
 
StringConcatColScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Vectorized instruction to concatenate a string column to a scalar and put the result in an output column.
StringConcatColScalar(int, byte[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColScalar
 
StringConcatColScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatColScalar
 
StringConcatScalarCol - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Vectorized instruction to concatenate a scalar to a string column and put the result in an output column.
StringConcatScalarCol(byte[], int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatScalarCol
 
StringConcatScalarCol() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringConcatScalarCol
 
stringEvaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcat
 
StringExpr - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
String expression evaluation helper functions.
StringExpr() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringExpr
 
StringHex - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
StringLength - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Calculate the length of the strings in the input column vector, and store it in the output column vector.
StringLength(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringLength
 
StringLength() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringLength
 
StringLower - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Expression to convert a string to lower case.
StringLower(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringLower
 
StringLower() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringLower
 
StringLTrim - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
StringLTrim(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringLTrim
 
StringLTrim() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringLTrim
 
StringNumDistinctValueEstimator - Class in org.apache.hadoop.hive.ql.udf.generic
 
StringNumDistinctValueEstimator(int) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.StringNumDistinctValueEstimator
 
StringNumDistinctValueEstimator(String, int) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.StringNumDistinctValueEstimator
 
StringRTrim - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
StringRTrim(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringRTrim
 
StringRTrim() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringRTrim
 
StringSubstrColStart - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This class provides the implementation of vectorized substring, with a single start index parameter.
StringSubstrColStart(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStart
 
StringSubstrColStart() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStart
 
StringSubstrColStartLen - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This class provides the implementation of vectorized substring, with a start index and length parameters.
StringSubstrColStartLen(int, int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStartLen
 
StringSubstrColStartLen() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringSubstrColStartLen
 
StringTrim - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
StringTrim(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringTrim
 
StringTrim() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringTrim
 
StringUnaryUDF - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Expression for vectorized evaluation of unary UDFs on strings.
StringUnaryUDF() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDF
 
StringUnaryUDF.IUDFUnaryString - Interface in org.apache.hadoop.hive.ql.exec.vector.expressions
 
StringUnaryUDFDirect - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This is a superclass for unary string functions that operate directly on the input and set the output.
StringUnaryUDFDirect(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDFDirect
 
StringUnaryUDFDirect() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUnaryUDFDirect
 
StringUpper - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Expression to convert a string to lower case.
StringUpper(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUpper
 
StringUpper() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.StringUpper
 
STRIPE_SIZE - Static variable in class org.apache.hadoop.hive.ql.io.orc.OrcFile
Deprecated. 
StripeInformation - Interface in org.apache.hadoop.hive.ql.io.orc
Information about the stripes in an ORC file that is provided by the Reader.
stripeSize(long) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
Set the stripe size for the file.
StripeStatistics - Class in org.apache.hadoop.hive.ql.io.orc
 
stripIdentifierQuotes(String) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
stripPrefixFromColumnName(String) - Static method in class org.apache.hadoop.hive.ql.stats.StatsUtils
Remove KEY/VALUE prefix from column name
stripQuotes(String) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
stripQuotes(String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
subList(int, int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
SubQueryUtils - Class in org.apache.hadoop.hive.ql.parse
 
SubQueryUtils() - Constructor for class org.apache.hadoop.hive.ql.parse.SubQueryUtils
 
SubQueryUtils.ISubQueryJoinInfo - Interface in org.apache.hadoop.hive.ql.parse
 
subscribeFeed(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Task
Subscribe the feed of publisher.
substitute(HiveConf, String) - Method in class org.apache.hadoop.hive.ql.parse.VariableSubstitution
 
subtractChecked(int, Decimal128, Decimal128, DecimalColumnVector) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil
 
suffix - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
sumLength - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator.BinaryStatsAgg
 
sumLength - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.StringStatsAgg
 
sumOf(Map<String, Long>, Set<String>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
sumOfExcept(Map<String, Long>, Set<String>, Set<String>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
supportAutomaticSortMergeJoin() - Method in class org.apache.hadoop.hive.ql.exec.FilterOperator
 
supportAutomaticSortMergeJoin() - Method in class org.apache.hadoop.hive.ql.exec.Operator
Whether this operator supports automatic sort merge join.
supportAutomaticSortMergeJoin() - Method in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
supportAutomaticSortMergeJoin() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
supportColumnLevel() - Method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
supportDBLevel() - Method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
supportsExplicitLock() - Method in class org.apache.hadoop.hive.ql.lockmgr.DbTxnManager
 
supportsExplicitLock() - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveTxnManager
Indicate whether this lock manager supports the use of lock database or lock table.
supportSkewJoinOptimization() - Method in class org.apache.hadoop.hive.ql.exec.FilterOperator
 
supportSkewJoinOptimization() - Method in class org.apache.hadoop.hive.ql.exec.JoinOperator
 
supportSkewJoinOptimization() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
supportSkewJoinOptimization() - Method in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
supportSkewJoinOptimization() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
supportTableLevel() - Method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
supportUnionRemoveOptimization() - Method in class org.apache.hadoop.hive.ql.exec.FilterOperator
 
supportUnionRemoveOptimization() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
supportUnionRemoveOptimization() - Method in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
SwitchDatabaseDesc - Class in org.apache.hadoop.hive.ql.plan
SwitchDatabaseDesc.
SwitchDatabaseDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.SwitchDatabaseDesc
 
SwitchDatabaseDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.SwitchDatabaseDesc
 
SymbolicInputFormat - Class in org.apache.hadoop.hive.ql.io
 
SymbolicInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.SymbolicInputFormat
 
SymlinkTextInputFormat - Class in org.apache.hadoop.hive.ql.io
Symlink file is a text file which contains a list of filename / dirname.
SymlinkTextInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat
 
SymlinkTextInputFormat.SymlinkTextInputSplit - Class in org.apache.hadoop.hive.ql.io
This input split wraps the FileSplit generated from TextInputFormat.getSplits(), while setting the original link file path as job input path.
SymlinkTextInputFormat.SymlinkTextInputSplit() - Constructor for class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat.SymlinkTextInputSplit
 
SymlinkTextInputFormat.SymlinkTextInputSplit(Path, FileSplit) - Constructor for class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat.SymlinkTextInputSplit
 
sync(long) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Seek to the next sync mark past a given position.
sync() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Writer
create a sync point.
sync(long) - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
sync(long) - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
SYNC_INTERVAL - Static variable in class org.apache.hadoop.hive.ql.io.RCFile
The number of bytes between sync points.
syncSeen() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Returns true iff the previous call to next passed a sync mark.
SYSTEM_PREFIX - Static variable in class org.apache.hadoop.hive.ql.processors.SetProcessor
 

T

tabCode - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
Table - Class in org.apache.hadoop.hive.ql.metadata
A Hive Table: is a fundamental unit of data in Hive that shares a common schema/DDL.
Table() - Constructor for class org.apache.hadoop.hive.ql.metadata.Table
Used only for serialization.
Table(Table) - Constructor for class org.apache.hadoop.hive.ql.metadata.Table
 
Table(String, String) - Constructor for class org.apache.hadoop.hive.ql.metadata.Table
 
TableAccessAnalyzer - Class in org.apache.hadoop.hive.ql.parse
TableAccessAnalyzer walks the operator graph from joins and group bys to the table scan operator backing it.
TableAccessAnalyzer() - Constructor for class org.apache.hadoop.hive.ql.parse.TableAccessAnalyzer
 
TableAccessAnalyzer(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.parse.TableAccessAnalyzer
 
TableAccessAnalyzer.GroupByProcessor - Class in org.apache.hadoop.hive.ql.parse
Processor for GroupBy operator
TableAccessAnalyzer.GroupByProcessor(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.parse.TableAccessAnalyzer.GroupByProcessor
 
TableAccessAnalyzer.JoinProcessor - Class in org.apache.hadoop.hive.ql.parse
Processor for Join operator.
TableAccessAnalyzer.JoinProcessor(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.parse.TableAccessAnalyzer.JoinProcessor
 
TableAccessCtx - Class in org.apache.hadoop.hive.ql.parse
This class implements the context information that is used for typechecking phase in query compilation.
TableAccessCtx() - Constructor for class org.apache.hadoop.hive.ql.parse.TableAccessCtx
Constructor.
TableAccessInfo - Class in org.apache.hadoop.hive.ql.parse
 
TableAccessInfo() - Constructor for class org.apache.hadoop.hive.ql.parse.TableAccessInfo
 
TableBasedIndexHandler - Class in org.apache.hadoop.hive.ql.index
Index handler for indexes that use tables to store indexes.
TableBasedIndexHandler() - Constructor for class org.apache.hadoop.hive.ql.index.TableBasedIndexHandler
 
TableDesc - Class in org.apache.hadoop.hive.ql.plan
TableDesc.
TableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.TableDesc
 
TableDesc(Class<? extends InputFormat>, Class<?>, Properties) - Constructor for class org.apache.hadoop.hive.ql.plan.TableDesc
 
TableFunctionEvaluator - Class in org.apache.hadoop.hive.ql.udf.ptf
Based on Hive GenericUDAFEvaluator.
TableFunctionEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
TableFunctionResolver - Class in org.apache.hadoop.hive.ql.udf.ptf
Based on Hive GenericUDAFResolver.
TableFunctionResolver() - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
 
tableHandle - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
tableName - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
tableProperties(Properties) - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
Provide the table properties for the table.
TableSample - Class in org.apache.hadoop.hive.ql.parse
This class stores all the information specified in the TABLESAMPLE clause.
TableSample(String, String, ArrayList<ASTNode>) - Constructor for class org.apache.hadoop.hive.ql.parse.TableSample
Constructs the TableSample given the numerator, denominator and the list of ON clause expressions.
TableSample(int, int) - Constructor for class org.apache.hadoop.hive.ql.parse.TableSample
 
TableScanDesc - Class in org.apache.hadoop.hive.ql.plan
Table Scan Descriptor Currently, data is only read from a base source as part of map-reduce framework.
TableScanDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
TableScanDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
TableScanDesc(String, List<VirtualColumn>) - Constructor for class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
TableScanOperator - Class in org.apache.hadoop.hive.ql.exec
Table Scan Operator If the data is coming from the map-reduce framework, just forward it.
TableScanOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
TableSizeBasedBigTableSelectorForAutoSMJ - Class in org.apache.hadoop.hive.ql.optimizer
 
TableSizeBasedBigTableSelectorForAutoSMJ() - Constructor for class org.apache.hadoop.hive.ql.optimizer.TableSizeBasedBigTableSelectorForAutoSMJ
 
Task<T extends Serializable> - Class in org.apache.hadoop.hive.ql.exec
Task implementation.
Task() - Constructor for class org.apache.hadoop.hive.ql.exec.Task
 
TASK - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
Task.FeedType - Enum in org.apache.hadoop.hive.ql.exec
 
taskClass - Variable in class org.apache.hadoop.hive.ql.exec.TaskFactory.TaskTuple
 
TaskCompiler - Class in org.apache.hadoop.hive.ql.parse
TaskCompiler is a the base class for classes that compile operator pipelines into tasks.
TaskCompiler() - Constructor for class org.apache.hadoop.hive.ql.parse.TaskCompiler
 
TaskCompilerFactory - Class in org.apache.hadoop.hive.ql.parse
TaskCompilerFactory is a factory class to choose the appropriate TaskCompiler.
taskCounters - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
TaskExecutionException - Exception in org.apache.hadoop.hive.ql.exec
Exception thrown by any task processor to signal a problem with task execution.
TaskExecutionException(String) - Constructor for exception org.apache.hadoop.hive.ql.exec.TaskExecutionException
 
TaskExecutionException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.ql.exec.TaskExecutionException
 
TaskExecutionException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.exec.TaskExecutionException
 
TaskFactory - Class in org.apache.hadoop.hive.ql.exec
TaskFactory implementation.
TaskFactory.TaskTuple<T extends Serializable> - Class in org.apache.hadoop.hive.ql.exec
taskTuple.
TaskFactory.TaskTuple(Class<T>, Class<? extends Task<T>>) - Constructor for class org.apache.hadoop.hive.ql.exec.TaskFactory.TaskTuple
 
TaskGraphWalker - Class in org.apache.hadoop.hive.ql.lib
base class for operator graph walker this class takes list of starting ops and walks them one by one.
TaskGraphWalker(Dispatcher) - Constructor for class org.apache.hadoop.hive.ql.lib.TaskGraphWalker
Constructor.
TaskGraphWalker.TaskGraphWalkerContext - Class in org.apache.hadoop.hive.ql.lib
 
TaskGraphWalker.TaskGraphWalkerContext(HashMap<Node, Object>) - Constructor for class org.apache.hadoop.hive.ql.lib.TaskGraphWalker.TaskGraphWalkerContext
 
taskHandle - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
TaskHandle - Class in org.apache.hadoop.hive.ql.exec
TaskHandle.
TaskHandle() - Constructor for class org.apache.hadoop.hive.ql.exec.TaskHandle
 
TaskLogProcessor - Class in org.apache.hadoop.hive.ql.exec.errors
TaskLogProcessor reads the logs from failed task attempts and tries to figure out what the cause of the error was using various heuristics.
TaskLogProcessor(JobConf) - Constructor for class org.apache.hadoop.hive.ql.exec.errors.TaskLogProcessor
 
TaskResult - Class in org.apache.hadoop.hive.ql.exec
TaskResult implementation.
TaskResult() - Constructor for class org.apache.hadoop.hive.ql.exec.TaskResult
 
TaskRunner - Class in org.apache.hadoop.hive.ql.exec
TaskRunner implementation.
TaskRunner(Task<? extends Serializable>, TaskResult) - Constructor for class org.apache.hadoop.hive.ql.exec.TaskRunner
 
taskvec - Static variable in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
TemporaryHashSinkOperator - Class in org.apache.hadoop.hive.ql.exec
 
TemporaryHashSinkOperator(MapJoinDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.TemporaryHashSinkOperator
 
TerminalOperator<T extends OperatorDesc> - Class in org.apache.hadoop.hive.ql.exec
Terminal Operator Base Class.
TerminalOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.TerminalOperator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovarianceSample.GenericUDAFCovarianceSampleEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCumeDist.GenericUDAFCumeDistEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Get final aggregation result.
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEWAHBitmap.GenericUDAFEWAHBitmapEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFFirstValue.GenericUDAFFirstValueEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLastValue.GenericUDAFLastValueEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMkCollectionEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFNTile.GenericUDAFNTileEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFMultiplePercentileApproxEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFSinglePercentileApproxEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentRank.GenericUDAFPercentRankEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank.GenericUDAFRankEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRowNumber.GenericUDAFRowNumberEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStd.GenericUDAFStdEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStdSample.GenericUDAFStdSampleEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumDouble
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumHiveDecimal
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumLong
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance.GenericUDAFVarianceEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVarianceSample.GenericUDAFVarianceSampleEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongArrayEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDecimalStatsEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Get partial aggregation result.
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEWAHBitmap.GenericUDAFEWAHBitmapEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFFirstValue.GenericUDAFFirstValueEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLastValue.GenericUDAFLastValueEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMkCollectionEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFNTile.GenericUDAFNTileEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRank.GenericUDAFRankEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFRowNumber.GenericUDAFRowNumberEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumDouble
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumHiveDecimal
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumLong
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance.GenericUDAFVarianceEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongArrayEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator
 
TextRecordReader - Class in org.apache.hadoop.hive.ql.exec
TextRecordReader.
TextRecordReader() - Constructor for class org.apache.hadoop.hive.ql.exec.TextRecordReader
 
TextRecordWriter - Class in org.apache.hadoop.hive.ql.exec
TextRecordWriter.
TextRecordWriter() - Constructor for class org.apache.hadoop.hive.ql.exec.TextRecordWriter
 
TEZ_BUILD_DAG - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
TEZ_CREATE_VERTEX - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
TEZ_INIT_OPERATORS - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
TEZ_INITIALIZE_PROCESSOR - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
TEZ_RUN_DAG - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
TEZ_RUN_PROCESSOR - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
TEZ_RUN_VERTEX - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
TEZ_SUBMIT_DAG - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
TEZ_SUBMIT_TO_RUNNING - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
TezBucketJoinProcCtx - Class in org.apache.hadoop.hive.ql.optimizer
 
TezBucketJoinProcCtx(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.optimizer.TezBucketJoinProcCtx
 
TezCacheAccess - Class in org.apache.hadoop.hive.ql.exec.tez
Access to the Object cache from Tez, along with utility methods for accessing specific Keys.
TezCompiler - Class in org.apache.hadoop.hive.ql.parse
TezCompiler translates the operator plan into TezTasks.
TezCompiler() - Constructor for class org.apache.hadoop.hive.ql.parse.TezCompiler
 
TezContext - Class in org.apache.hadoop.hive.ql.exec.tez
TezContext contains additional context only available with Tez
TezContext(boolean, JobConf) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.TezContext
 
TezEdgeProperty - Class in org.apache.hadoop.hive.ql.plan
 
TezEdgeProperty(HiveConf, TezEdgeProperty.EdgeType, int) - Constructor for class org.apache.hadoop.hive.ql.plan.TezEdgeProperty
 
TezEdgeProperty(TezEdgeProperty.EdgeType) - Constructor for class org.apache.hadoop.hive.ql.plan.TezEdgeProperty
 
TezEdgeProperty.EdgeType - Enum in org.apache.hadoop.hive.ql.plan
 
TezJobMonitor - Class in org.apache.hadoop.hive.ql.exec.tez
TezJobMonitor keeps track of a tez job while it's being executed.
TezJobMonitor() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.TezJobMonitor
 
TezMergedLogicalInput - Class in org.apache.hadoop.hive.ql.exec.tez.tools
TezMergedLogicalInput is an adapter to make union input look like a single input in tez.
TezMergedLogicalInput() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.tools.TezMergedLogicalInput
 
TezProcessor - Class in org.apache.hadoop.hive.ql.exec.tez
Hive processor for Tez that forms the vertices in Tez and processes the data.
TezProcessor(boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.TezProcessor
 
TezSessionPoolManager - Class in org.apache.hadoop.hive.ql.exec.tez
This class is for managing multiple tez sessions particularly when HiveServer2 is being used to submit queries.
TezSessionState - Class in org.apache.hadoop.hive.ql.exec.tez
Holds session state related to Tez
TezSessionState(DagUtils) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
Constructor.
TezSessionState(String) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.TezSessionState
Constructor.
TezTask - Class in org.apache.hadoop.hive.ql.exec.tez
TezTask handles the execution of TezWork.
TezTask() - Constructor for class org.apache.hadoop.hive.ql.exec.tez.TezTask
 
TezTask(DagUtils) - Constructor for class org.apache.hadoop.hive.ql.exec.tez.TezTask
 
TezWalker - Class in org.apache.hadoop.hive.ql.parse
Walks the operator tree in DFS fashion.
TezWalker(Dispatcher) - Constructor for class org.apache.hadoop.hive.ql.parse.TezWalker
constructor of the walker - the dispatcher is passed.
TezWork - Class in org.apache.hadoop.hive.ql.plan
TezWork.
TezWork(String) - Constructor for class org.apache.hadoop.hive.ql.plan.TezWork
 
TezWork.Dependency - Class in org.apache.hadoop.hive.ql.plan
 
TezWork.Dependency() - Constructor for class org.apache.hadoop.hive.ql.plan.TezWork.Dependency
 
Throttle - Class in org.apache.hadoop.hive.ql.exec.mr
Intelligence to make clients wait if the cluster is in a bad state.
TIME_TO_SUBMIT - Static variable in class org.apache.hadoop.hive.ql.log.PerfLogger
 
TimestampUtils - Class in org.apache.hadoop.hive.ql.exec.vector
 
TimestampUtils() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.TimestampUtils
 
toArray() - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
toBinaryString() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
toBool(long) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
toBool(double) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
toCachedEval(ExprNodeEvaluator) - Static method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluatorFactory
Should be called before eval is initialized
toColumnDesc() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
toColumns(List<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.optimizer.AbstractBucketJoinProc
 
todo(String) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.HiveOptiqUtil
Deprecated. 
todo(String) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.JoinUtil
Deprecated. 
toKryo() - Method in interface org.apache.hadoop.hive.ql.io.sarg.SearchArgument
Serialize the SARG as a kyro object and return the base64 string.
TOLERATE_CORRUPTIONS_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.io.RCFile
 
TopNHash - Class in org.apache.hadoop.hive.ql.exec
Stores binary key/value in sorted manner to get top-n key/value TODO: rename to TopNHeap?
TopNHash() - Constructor for class org.apache.hadoop.hive.ql.exec.TopNHash
 
TopNHash.BinaryCollector - Interface in org.apache.hadoop.hive.ql.exec
For interaction between operator and top-n hash.
toRel(RelOptTable.ToRelContext) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.RelOptHiveTable
 
toString() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
Returns the string representation of the ColumnInfo.
toString() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
toString(Collection<Operator<? extends OperatorDesc>>) - Static method in class org.apache.hadoop.hive.ql.exec.Operator
 
toString() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectSerDeContext
 
toString(List<?>) - Static method in class org.apache.hadoop.hive.ql.exec.PTFUtils
 
toString(Map<?, ?>) - Static method in class org.apache.hadoop.hive.ql.exec.PTFUtils
 
toString() - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
toString() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
toString() - Method in class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression
 
toString() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Descriptor
 
toString() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
toString() - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
toString() - Method in class org.apache.hadoop.hive.ql.hooks.Entity
toString function.
toString() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapInnerQuery
Return a string representation of the query string for compilation
toString() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapOuterQuery
Return a string representation of the query for compilation
toString() - Method in interface org.apache.hadoop.hive.ql.index.bitmap.BitmapQuery
 
toString() - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
toString() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
toString() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Prints this obejct as a string.
toString() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
toString() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcStruct
 
toString() - Method in class org.apache.hadoop.hive.ql.io.orc.Reader.Options
 
toString() - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
toString() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Returns the name of the file.
toString() - Method in class org.apache.hadoop.hive.ql.io.RecordIdentifier
 
toString() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
toString() - Method in class org.apache.hadoop.hive.ql.MapRedStats
 
toString() - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult.PartitionResult
 
toString() - Method in class org.apache.hadoop.hive.ql.metadata.Dimension
 
toString() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
toString() - Method in class org.apache.hadoop.hive.ql.metadata.Sample
 
toString() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
toString() - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.cost.HiveCost
 
toString() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.BucketCol
 
toString() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtx.SortCol
 
toString() - Method in class org.apache.hadoop.hive.ql.parse.ASTErrorNode
 
toString() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
toString() - Method in class org.apache.hadoop.hive.ql.parse.InputSignature
 
toString() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderExpression
 
toString() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.OrderSpec
 
toString() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionExpression
 
toString() - Method in class org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PartitionSpec
 
toString() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
toString() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.CurrentRowSpec
 
toString() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.RangeBoundarySpec
 
toString() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.ValueBoundarySpec
 
toString() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFrameSpec
 
toString() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFunctionSpec
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.BucketMapJoinContext
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.ColStatistics
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.ColumnStatsWork
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
toString() - Method in enum org.apache.hadoop.hive.ql.plan.RoleDDLDesc.RoleOperation
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
toString() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
toString() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrincipal
 
toString() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilege
 
toString() - Method in class org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject
 
toString() - Method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLPrivTypeGrant
 
toString() - Method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
toString() - Method in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeType
 
toString() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFExplode
 
toString() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFInline
 
toString() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFJSONTuple
 
toString() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFParseUrlTuple
 
toString() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFPosExplode
 
toString() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFStack
 
toTaskTempPath(Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
toTempPath(Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
toTempPath(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Given a path, convert to a temporary path.
toThriftJSONString() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
TraitsUtil - Class in org.apache.hadoop.hive.ql.optimizer.optiq
 
TraitsUtil() - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.TraitsUtil
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketingSortingReduceSinkOptimizer
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketMapJoinOptimizer
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPruner
Transform the query tree.
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationOptimizer
Detect correlations and transform the query tree.
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.correlation.ReduceSinkDeDuplication
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.GlobalLimitOptimizer
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.index.RewriteGBUsingIndex
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.JoinReorder
Transform the query tree.
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.LimitPushdownOptimizer
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.Generator
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPruner
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
Transform the query tree.
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.AnnotateWithOpTraits
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.NonBlockingOpDeDupProc
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PartitionConditionRemover
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.SimpleFetchAggregation
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.SimpleFetchOptimizer
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.SkewJoinOptimizer
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.SortedDynPartitionOptimizer
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.SortedMergeBucketMapJoinOptimizer
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.stats.annotation.AnnotateWithStatistics
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.StatsOptimizer
 
Transform - Interface in org.apache.hadoop.hive.ql.optimizer
Optimizer interface.
transform(ParseContext) - Method in interface org.apache.hadoop.hive.ql.optimizer.Transform
All transformation steps implement this interface.
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcessor
Transform the query tree.
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.ppd.PredicatePushDown
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.ppd.PredicateTransitivePropagate
 
transformRawInput(PTFPartition) - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionEvaluator
 
transformsRawInput() - Method in class org.apache.hadoop.hive.ql.udf.ptf.Noop.NoopResolver
 
transformsRawInput() - Method in class org.apache.hadoop.hive.ql.udf.ptf.NoopWithMap.NoopWithMapResolver
 
transformsRawInput() - Method in class org.apache.hadoop.hive.ql.udf.ptf.TableFunctionResolver
 
transformsRawInput() - Method in class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.WindowingTableFunctionResolver
 
translate(PTFInvocationSpec, SemanticAnalyzer, HiveConf, RowResolver, UnparseTranslator) - Method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
translate(WindowingSpec, SemanticAnalyzer, HiveConf, RowResolver, UnparseTranslator) - Method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
translateBitSetToProjIndx(BitSet) - Static method in class org.apache.hadoop.hive.ql.optimizer.optiq.HiveOptiqUtil
 
translateSearchConditions(List<IndexSearchCondition>) - Method in class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
Translates search conditions back to ExprNodeDesc form (as a left-deep conjunction).
traverse(Task<?>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.StageIDsRearranger.TaskTraverse
 
TruncateTableDesc - Class in org.apache.hadoop.hive.ql.plan
Truncates managed table or partition
TruncateTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.TruncateTableDesc
 
TruncateTableDesc(String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.TruncateTableDesc
 
tryStoreKey(HiveKey) - Method in class org.apache.hadoop.hive.ql.exec.TopNHash
Try store the non-vectorized key.
tryStoreVectorizedKey(HiveKey, int) - Method in class org.apache.hadoop.hive.ql.exec.TopNHash
Try to put the key from the current vectorized batch into the heap.
TxnManagerFactory - Class in org.apache.hadoop.hive.ql.lockmgr
A factory to get an instance of HiveTxnManager.
type - Variable in class org.apache.hadoop.hive.ql.plan.TezWork.Dependency
 
TypeCheckCtx - Class in org.apache.hadoop.hive.ql.parse
This class implements the context information that is used for typechecking phase in query compilation.
TypeCheckCtx(RowResolver) - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
Constructor.
TypeCheckProcFactory - Class in org.apache.hadoop.hive.ql.parse
The Factory for creating typecheck processors.
TypeCheckProcFactory.BoolExprProcessor - Class in org.apache.hadoop.hive.ql.parse
Processor for boolean constants.
TypeCheckProcFactory.BoolExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.BoolExprProcessor
 
TypeCheckProcFactory.ColumnExprProcessor - Class in org.apache.hadoop.hive.ql.parse
Processor for table columns.
TypeCheckProcFactory.ColumnExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.ColumnExprProcessor
 
TypeCheckProcFactory.DateExprProcessor - Class in org.apache.hadoop.hive.ql.parse
Processor for date constants.
TypeCheckProcFactory.DateExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DateExprProcessor
 
TypeCheckProcFactory.DefaultExprProcessor - Class in org.apache.hadoop.hive.ql.parse
The default processor for typechecking.
TypeCheckProcFactory.DefaultExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
 
TypeCheckProcFactory.NullExprProcessor - Class in org.apache.hadoop.hive.ql.parse
Processor for processing NULL expression.
TypeCheckProcFactory.NullExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.NullExprProcessor
 
TypeCheckProcFactory.NumExprProcessor - Class in org.apache.hadoop.hive.ql.parse
Processor for processing numeric constants.
TypeCheckProcFactory.NumExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.NumExprProcessor
 
TypeCheckProcFactory.StrExprProcessor - Class in org.apache.hadoop.hive.ql.parse
Processor for processing string constants.
TypeCheckProcFactory.StrExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.StrExprProcessor
 
TypeCheckProcFactory.SubQueryExprProcessor - Class in org.apache.hadoop.hive.ql.parse
Processor for subquery expressions..
TypeCheckProcFactory.SubQueryExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.SubQueryExprProcessor
 
TypeConverter - Class in org.apache.hadoop.hive.ql.optimizer.optiq.translator
 
TypeConverter() - Constructor for class org.apache.hadoop.hive.ql.optimizer.optiq.translator.TypeConverter
 

U

UDAF - Class in org.apache.hadoop.hive.ql.exec
Deprecated. 
UDAF() - Constructor for class org.apache.hadoop.hive.ql.exec.UDAF
Deprecated. The default constructor.
UDAF(UDAFEvaluatorResolver) - Constructor for class org.apache.hadoop.hive.ql.exec.UDAF
Deprecated. The constructor with a particular type of resolver.
UDAFEvaluator - Interface in org.apache.hadoop.hive.ql.exec
Interface that encapsulates the evaluation logic of a UDAF.
UDAFEvaluatorResolver - Interface in org.apache.hadoop.hive.ql.exec
The UDF Method resolver interface.
UDAFPercentile - Class in org.apache.hadoop.hive.ql.udf
UDAF for calculating the percentile values.
UDAFPercentile() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFPercentile
 
UDAFPercentile.MyComparator - Class in org.apache.hadoop.hive.ql.udf
A comparator to sort the entries in order.
UDAFPercentile.MyComparator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFPercentile.MyComparator
 
UDAFPercentile.PercentileLongArrayEvaluator - Class in org.apache.hadoop.hive.ql.udf
The evaluator for percentile computation based on long for an array of percentiles.
UDAFPercentile.PercentileLongArrayEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongArrayEvaluator
 
UDAFPercentile.PercentileLongEvaluator - Class in org.apache.hadoop.hive.ql.udf
The evaluator for percentile computation based on long.
UDAFPercentile.PercentileLongEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongEvaluator
 
UDAFPercentile.State - Class in org.apache.hadoop.hive.ql.udf
A state class to store intermediate aggregation results.
UDAFPercentile.State() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFPercentile.State
 
UDAFWrongArgLengthForTestCase - Class in org.apache.hadoop.hive.ql.udf
UDAFWrongArgLengthForTestCase.
UDAFWrongArgLengthForTestCase() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFWrongArgLengthForTestCase
 
UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator - Class in org.apache.hadoop.hive.ql.udf
UDAFWrongArgLengthForTestCaseEvaluator.
UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator
 
UDF - Class in org.apache.hadoop.hive.ql.exec
A User-defined function (UDF) for the use with Hive.
UDF() - Constructor for class org.apache.hadoop.hive.ql.exec.UDF
The constructor.
UDFAcos - Class in org.apache.hadoop.hive.ql.udf
UDFAcos.
UDFAcos() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFAcos
 
UDFArgumentException - Exception in org.apache.hadoop.hive.ql.exec
exception class, thrown when udf argument have something wrong.
UDFArgumentException() - Constructor for exception org.apache.hadoop.hive.ql.exec.UDFArgumentException
 
UDFArgumentException(String) - Constructor for exception org.apache.hadoop.hive.ql.exec.UDFArgumentException
 
UDFArgumentException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.exec.UDFArgumentException
 
UDFArgumentException(String, Class<?>, List<TypeInfo>, List<Method>) - Constructor for exception org.apache.hadoop.hive.ql.exec.UDFArgumentException
Constructor.
UDFArgumentLengthException - Exception in org.apache.hadoop.hive.ql.exec
exception class, thrown when udf arguments have wrong length.
UDFArgumentLengthException(String) - Constructor for exception org.apache.hadoop.hive.ql.exec.UDFArgumentLengthException
 
UDFArgumentTypeException - Exception in org.apache.hadoop.hive.ql.exec
exception class, thrown when udf arguments have wrong types.
UDFArgumentTypeException() - Constructor for exception org.apache.hadoop.hive.ql.exec.UDFArgumentTypeException
 
UDFArgumentTypeException(int, String) - Constructor for exception org.apache.hadoop.hive.ql.exec.UDFArgumentTypeException
 
UDFAscii - Class in org.apache.hadoop.hive.ql.udf
UDFAscii.
UDFAscii() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFAscii
 
UDFAsin - Class in org.apache.hadoop.hive.ql.udf
UDFAsin.
UDFAsin() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFAsin
 
UDFAtan - Class in org.apache.hadoop.hive.ql.udf
 
UDFAtan() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFAtan
 
UDFBase64 - Class in org.apache.hadoop.hive.ql.udf
 
UDFBase64() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFBase64
 
UDFBaseBitOP - Class in org.apache.hadoop.hive.ql.udf
Base class for numeric operators like +, -, / etc.
UDFBaseBitOP() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFBaseBitOP
Constructor.
UDFBin - Class in org.apache.hadoop.hive.ql.udf
UDFBin.
UDFBin() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFBin
 
UDFConv - Class in org.apache.hadoop.hive.ql.udf
UDFConv.
UDFConv() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFConv
 
UDFCos - Class in org.apache.hadoop.hive.ql.udf
UDFCos.
UDFCos() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFCos
 
UDFCurrentDB - Class in org.apache.hadoop.hive.ql.udf.generic
 
UDFCurrentDB() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.UDFCurrentDB
 
UDFDayOfMonth - Class in org.apache.hadoop.hive.ql.udf
UDFDayOfMonth.
UDFDayOfMonth() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFDayOfMonth
 
UDFDegrees - Class in org.apache.hadoop.hive.ql.udf
 
UDFDegrees() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFDegrees
 
UDFE - Class in org.apache.hadoop.hive.ql.udf
 
UDFE() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFE
 
UDFExp - Class in org.apache.hadoop.hive.ql.udf
UDFExp.
UDFExp() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFExp
 
UDFFindInSet - Class in org.apache.hadoop.hive.ql.udf
UDFFindInSet.
UDFFindInSet() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFFindInSet
 
UDFFromUnixTime - Class in org.apache.hadoop.hive.ql.udf
UDFFromUnixTime.
UDFFromUnixTime() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFFromUnixTime
 
UDFHex - Class in org.apache.hadoop.hive.ql.udf
UDFHex.
UDFHex() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFHex
 
UDFHour - Class in org.apache.hadoop.hive.ql.udf
UDFHour.
UDFHour() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFHour
 
UDFJson - Class in org.apache.hadoop.hive.ql.udf
UDFJson.
UDFJson() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFJson
 
UDFLength - Class in org.apache.hadoop.hive.ql.udf
UDFLength.
UDFLength() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLength
 
UDFLike - Class in org.apache.hadoop.hive.ql.udf
UDFLike.
UDFLike() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLike
 
UDFLn - Class in org.apache.hadoop.hive.ql.udf
UDFLn.
UDFLn() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLn
 
UDFLog - Class in org.apache.hadoop.hive.ql.udf
UDFLog.
UDFLog() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLog
 
UDFLog10 - Class in org.apache.hadoop.hive.ql.udf
UDFLog10.
UDFLog10() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLog10
 
UDFLog2 - Class in org.apache.hadoop.hive.ql.udf
UDFLog2.
UDFLog2() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLog2
 
UDFMath - Class in org.apache.hadoop.hive.ql.udf
 
UDFMath() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFMath
 
UDFMethodResolver - Interface in org.apache.hadoop.hive.ql.exec
The UDF Method resolver interface.
UDFMinute - Class in org.apache.hadoop.hive.ql.udf
UDFMinute.
UDFMinute() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFMinute
 
UDFMonth - Class in org.apache.hadoop.hive.ql.udf
UDFMonth.
UDFMonth() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFMonth
 
UDFOPBitAnd - Class in org.apache.hadoop.hive.ql.udf
UDFOPBitAnd.
UDFOPBitAnd() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPBitAnd
 
UDFOPBitNot - Class in org.apache.hadoop.hive.ql.udf
UDFOPBitNot.
UDFOPBitNot() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPBitNot
 
UDFOPBitOr - Class in org.apache.hadoop.hive.ql.udf
UDFOPBitOr.
UDFOPBitOr() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPBitOr
 
UDFOPBitXor - Class in org.apache.hadoop.hive.ql.udf
UDFOPBitXor.
UDFOPBitXor() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPBitXor
 
UDFOPLongDivide - Class in org.apache.hadoop.hive.ql.udf
UDFOPLongDivide.
UDFOPLongDivide() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPLongDivide
 
UDFParseUrl - Class in org.apache.hadoop.hive.ql.udf
UDF to extract specfic parts from URL For example, parse_url('http://facebook.com/path/p1.php?query=1', 'HOST') will return 'facebook.com' For example, parse_url('http://facebook.com/path/p1.php?query=1', 'PATH') will return '/path/p1.php' parse_url('http://facebook.com/path/p1.php?query=1', 'QUERY') will return 'query=1' parse_url('http://facebook.com/path/p1.php?query=1#Ref', 'REF') will return 'Ref' parse_url('http://facebook.com/path/p1.php?query=1#Ref', 'PROTOCOL') will return 'http' Possible values are HOST,PATH,QUERY,REF,PROTOCOL,AUTHORITY,FILE,USERINFO Also you can get a value of particular key in QUERY, using syntax QUERY: eg: QUERY:k1.
UDFParseUrl() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFParseUrl
 
UDFPI - Class in org.apache.hadoop.hive.ql.udf
 
UDFPI() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFPI
 
UDFRadians - Class in org.apache.hadoop.hive.ql.udf
 
UDFRadians() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRadians
 
UDFRand - Class in org.apache.hadoop.hive.ql.udf
UDFRand.
UDFRand() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRand
 
UDFRegExp - Class in org.apache.hadoop.hive.ql.udf
UDFRegExp.
UDFRegExp() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRegExp
 
UDFRegExpExtract - Class in org.apache.hadoop.hive.ql.udf
UDF to extract a specific group identified by a java regex.
UDFRegExpExtract() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRegExpExtract
 
UDFRegExpReplace - Class in org.apache.hadoop.hive.ql.udf
UDFRegExpReplace.
UDFRegExpReplace() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRegExpReplace
 
UDFRepeat - Class in org.apache.hadoop.hive.ql.udf
UDFRepeat.
UDFRepeat() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRepeat
 
UDFReverse - Class in org.apache.hadoop.hive.ql.udf
UDFReverse.
UDFReverse() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFReverse
 
UDFSecond - Class in org.apache.hadoop.hive.ql.udf
UDFSecond.
UDFSecond() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFSecond
 
UDFSign - Class in org.apache.hadoop.hive.ql.udf
 
UDFSign() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFSign
 
UDFSin - Class in org.apache.hadoop.hive.ql.udf
UDFSin.
UDFSin() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFSin
 
UDFSpace - Class in org.apache.hadoop.hive.ql.udf
UDFSpace.
UDFSpace() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFSpace
 
UDFSqrt - Class in org.apache.hadoop.hive.ql.udf
Implementation of the SQRT UDF found in many databases.
UDFSqrt() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFSqrt
 
UDFSubstr - Class in org.apache.hadoop.hive.ql.udf
UDFSubstr.
UDFSubstr() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFSubstr
 
UDFTan - Class in org.apache.hadoop.hive.ql.udf
 
UDFTan() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFTan
 
UDFToBoolean - Class in org.apache.hadoop.hive.ql.udf
UDFToBoolean.
UDFToBoolean() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToBoolean
 
UDFToByte - Class in org.apache.hadoop.hive.ql.udf
UDFToByte.
UDFToByte() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToByte
 
UDFToDouble - Class in org.apache.hadoop.hive.ql.udf
UDFToDouble.
UDFToDouble() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToDouble
 
UDFToFloat - Class in org.apache.hadoop.hive.ql.udf
UDFToFloat.
UDFToFloat() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToFloat
 
UDFToInteger - Class in org.apache.hadoop.hive.ql.udf
UDFToInteger.
UDFToInteger() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToInteger
 
UDFToLong - Class in org.apache.hadoop.hive.ql.udf
UDFToLong.
UDFToLong() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToLong
 
UDFToShort - Class in org.apache.hadoop.hive.ql.udf
UDFToShort.
UDFToShort() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToShort
 
UDFToString - Class in org.apache.hadoop.hive.ql.udf
UDFToString.
UDFToString() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToString
 
UDFType - Annotation Type in org.apache.hadoop.hive.ql.udf
UDFType.
UDFUnbase64 - Class in org.apache.hadoop.hive.ql.udf
 
UDFUnbase64() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFUnbase64
 
UDFUnhex - Class in org.apache.hadoop.hive.ql.udf
UDFUnhex.
UDFUnhex() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFUnhex
 
UDFWeekOfYear - Class in org.apache.hadoop.hive.ql.udf
UDFWeekOfYear.
UDFWeekOfYear() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFWeekOfYear
 
UDFXPathBoolean - Class in org.apache.hadoop.hive.ql.udf.xml
 
UDFXPathBoolean() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathBoolean
 
UDFXPathDouble - Class in org.apache.hadoop.hive.ql.udf.xml
 
UDFXPathDouble() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathDouble
 
UDFXPathFloat - Class in org.apache.hadoop.hive.ql.udf.xml
 
UDFXPathFloat() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathFloat
 
UDFXPathInteger - Class in org.apache.hadoop.hive.ql.udf.xml
 
UDFXPathInteger() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathInteger
 
UDFXPathLong - Class in org.apache.hadoop.hive.ql.udf.xml
 
UDFXPathLong() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathLong
 
UDFXPathShort - Class in org.apache.hadoop.hive.ql.udf.xml
 
UDFXPathShort() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathShort
 
UDFXPathString - Class in org.apache.hadoop.hive.ql.udf.xml
 
UDFXPathString() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathString
 
UDFXPathUtil - Class in org.apache.hadoop.hive.ql.udf.xml
Utility class for all XPath UDFs.
UDFXPathUtil() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil
 
UDFXPathUtil.ReusableStringReader - Class in org.apache.hadoop.hive.ql.udf.xml
Reusable, non-threadsafe version of StringReader.
UDFXPathUtil.ReusableStringReader() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
UDFYear - Class in org.apache.hadoop.hive.ql.udf
UDFYear.
UDFYear() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFYear
 
UDTF_TAG - Static variable in class org.apache.hadoop.hive.ql.exec.LateralViewJoinOperator
 
UDTFCollector - Class in org.apache.hadoop.hive.ql.udf.generic
UDTFCollector collects data from a GenericUDTF and passes the data to a UDTFOperator.
UDTFCollector(UDTFOperator) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.UDTFCollector
 
UDTFDesc - Class in org.apache.hadoop.hive.ql.plan
All member variables should have a setters and getters of the form get and set or else they won't be recreated properly at run time.
UDTFDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.UDTFDesc
 
UDTFDesc(GenericUDTF, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.UDTFDesc
 
UDTFOperator - Class in org.apache.hadoop.hive.ql.exec
UDTFOperator.
UDTFOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
UNBOUNDED_AMOUNT - Static variable in class org.apache.hadoop.hive.ql.parse.WindowingSpec.BoundarySpec
 
unescapeIdentifier(String) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Remove the encapsulating "`" pair from the identifier.
unescapeQueryString(String) - Static method in class org.apache.hadoop.hive.ql.exec.PTFUtils
 
unescapeSQLString(String) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
unescapeText(Text) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
unFlatten() - Method in class org.apache.hadoop.hive.ql.exec.vector.ColumnVector
Restore the state of isRepeating and noNulls to what it was before flattening.
UnionDesc - Class in org.apache.hadoop.hive.ql.plan
unionDesc is a empty class currently.
UnionDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.UnionDesc
 
UnionOperator - Class in org.apache.hadoop.hive.ql.exec
Union Operator Just forwards.
UnionOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.UnionOperator
 
UnionProcContext - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
UnionProcContext.
UnionProcContext() - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext
 
UnionProcContext.UnionParseContext - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
UnionParseContext.
UnionProcContext.UnionParseContext(int) - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
UnionProcessor - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
Implementation of the union processor.
UnionProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcessor
empty constructor.
UnionProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
Operator factory for union processing.
UnionProcFactory.MapRedUnion - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
MapRed subquery followed by Union.
UnionProcFactory.MapRedUnion() - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory.MapRedUnion
 
UnionProcFactory.MapUnion - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
Map-only subquery followed by Union.
UnionProcFactory.MapUnion() - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory.MapUnion
 
UnionProcFactory.NoUnion - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
Default processor.
UnionProcFactory.NoUnion() - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory.NoUnion
 
UnionProcFactory.UnionNoProcessFile - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
Union followed by no processing.
UnionProcFactory.UnionNoProcessFile() - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory.UnionNoProcessFile
 
UnionProcFactory.UnknownUnion - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
Union subquery followed by Union.
UnionProcFactory.UnknownUnion() - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory.UnknownUnion
 
UnionWork - Class in org.apache.hadoop.hive.ql.plan
Simple wrapper for union all cases.
UnionWork() - Constructor for class org.apache.hadoop.hive.ql.plan.UnionWork
 
UnionWork(String) - Constructor for class org.apache.hadoop.hive.ql.plan.UnionWork
 
unionWorkMap - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
UNIQUE_JOIN - Static variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
uniqueElementsList(List<List<String>>, String) - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPruner.DynamicMultiDimensionalCollection
Convert value to unique element list.
uniqueSkewedValueList(List<List<String>>) - Static method in class org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPruner.DynamicMultiDimensionalCollection
Convert value to unique skewed value list.
unlock(HiveLock) - Method in class org.apache.hadoop.hive.ql.lockmgr.DbLockManager
 
unlock(HiveLock) - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
unlock(HiveLock, int, int) - Method in class org.apache.hadoop.hive.ql.lockmgr.EmbeddedLockManager
 
unlock(HiveLock) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
unlock(HiveLock) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
UnlockDatabaseDesc - Class in org.apache.hadoop.hive.ql.plan
UnlockDatabaseDesc.
UnlockDatabaseDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.UnlockDatabaseDesc
 
UnlockTableDesc - Class in org.apache.hadoop.hive.ql.plan
UnlockTableDesc.
UnlockTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.UnlockTableDesc
 
UnlockTableDesc(String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.UnlockTableDesc
 
unparseIdentifier(String) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
Regenerate an identifier as part of unparsing it back to SQL text.
unparseIdentifier(String, Configuration) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
unregisterJar(String) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
unregisterTemporaryUDF(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
unsetDataLocation() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
unwrap(Class<T>) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.RelOptHiveTable
 
update(long, long, long, Object) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater
 
update(long, long, long, Object) - Method in interface org.apache.hadoop.hive.ql.io.RecordUpdater
Update an old record with a new set of values.
update(BaseSemanticAnalyzer) - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContext
This should be called after the semantic analyzer completes.
update(BaseSemanticAnalyzer) - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
update(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ReturnObjectInspectorResolver
Update returnObjectInspector and valueInspectorsAreTheSame based on the ObjectInspector seen.
updateBuffer(JobConf, RecordReader, WritableComparable, Writable) - Method in class org.apache.hadoop.hive.ql.exec.FooterBuffer
Enqueue most recent record read, and dequeue earliest result in the queue.
updateColumnStatsState(Statistics.State) - Method in class org.apache.hadoop.hive.ql.plan.Statistics
 
updateConfigurationForEdge(JobConf, Vertex, JobConf, Vertex) - Method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
Given two vertices a, b update their configurations to be used in an Edge a-b
UpdateInputAccessTimeHook - Class in org.apache.hadoop.hive.ql.hooks
Implementation of a pre execute hook that updates the access times for all the inputs.
UpdateInputAccessTimeHook() - Constructor for class org.apache.hadoop.hive.ql.hooks.UpdateInputAccessTimeHook
 
UpdateInputAccessTimeHook.PreExec - Class in org.apache.hadoop.hive.ql.hooks
 
UpdateInputAccessTimeHook.PreExec() - Constructor for class org.apache.hadoop.hive.ql.hooks.UpdateInputAccessTimeHook.PreExec
 
updateOpParseCtx(Operator<? extends OperatorDesc>, OpParseContext) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
Update the OpParseContext of operator op to newOpParseContext.
updatePartitionColumnStatistics(ColumnStatistics) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
updateSkewJoinJobCounter(int) - Method in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
updateTableColumnStatistics(ColumnStatistics) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
useDummy(PrintStream) - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
Temporary switch while we are in development that replaces the implementation with a dummy one that just prints to stream.
useNewShowLocksFormat() - Method in class org.apache.hadoop.hive.ql.lockmgr.DbTxnManager
 
useNewShowLocksFormat() - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveTxnManager
Indicate whether this transaction manager returns information about locks in the new format for show locks or the old one.
usesIndexTable() - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapIndexHandler
 
usesIndexTable() - Method in class org.apache.hadoop.hive.ql.index.compact.CompactIndexHandler
 
usesIndexTable() - Method in interface org.apache.hadoop.hive.ql.index.HiveIndexHandler
Determines whether this handler implements indexes by creating an index table.
usesIndexTable() - Method in class org.apache.hadoop.hive.ql.index.TableBasedIndexHandler
 
useSorted() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
usesScript() - Method in class org.apache.hadoop.hive.ql.QueryProperties
 
Utilities - Class in org.apache.hadoop.hive.ql.exec
Utilities.
Utilities.CollectionPersistenceDelegate - Class in org.apache.hadoop.hive.ql.exec
 
Utilities.CollectionPersistenceDelegate() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.CollectionPersistenceDelegate
 
Utilities.CommonTokenDelegate - Class in org.apache.hadoop.hive.ql.exec
Need to serialize org.antlr.runtime.CommonToken
Utilities.CommonTokenDelegate() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.CommonTokenDelegate
 
Utilities.DatePersistenceDelegate - Class in org.apache.hadoop.hive.ql.exec
DatePersistenceDelegate.
Utilities.DatePersistenceDelegate() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.DatePersistenceDelegate
 
Utilities.EnumDelegate - Class in org.apache.hadoop.hive.ql.exec
Java 1.5 workaround.
Utilities.EnumDelegate() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.EnumDelegate
 
Utilities.ListDelegate - Class in org.apache.hadoop.hive.ql.exec
 
Utilities.ListDelegate() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.ListDelegate
 
Utilities.MapDelegate - Class in org.apache.hadoop.hive.ql.exec
 
Utilities.MapDelegate() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.MapDelegate
 
Utilities.PathDelegate - Class in org.apache.hadoop.hive.ql.exec
 
Utilities.PathDelegate() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.PathDelegate
 
Utilities.ReduceField - Enum in org.apache.hadoop.hive.ql.exec
ReduceField: KEY: record key VALUE: record value
Utilities.SetDelegate - Class in org.apache.hadoop.hive.ql.exec
 
Utilities.SetDelegate() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.SetDelegate
 
Utilities.SQLCommand<T> - Class in org.apache.hadoop.hive.ql.exec
 
Utilities.SQLCommand() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.SQLCommand
 
Utilities.StreamPrinter - Class in org.apache.hadoop.hive.ql.exec
StreamPrinter.
Utilities.StreamPrinter(InputStream, String, PrintStream) - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.StreamPrinter
 
Utilities.StreamStatus - Enum in org.apache.hadoop.hive.ql.exec
StreamStatus.
Utilities.TimestampPersistenceDelegate - Class in org.apache.hadoop.hive.ql.exec
TimestampPersistenceDelegate.
Utilities.TimestampPersistenceDelegate() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.TimestampPersistenceDelegate
 
Utils - Class in org.apache.hadoop.hive.ql.lib
Contains common utility functions to manipulate nodes, walkers etc.
Utils() - Constructor for class org.apache.hadoop.hive.ql.lib.Utils
 

V

validate() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
validate() - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
validate() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
Validate alter table description.
validate(HiveConf) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
validateAndMakeEffective() - Method in class org.apache.hadoop.hive.ql.parse.WindowingSpec
 
validateColumnNames(List<String>, List<String>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
validateColumnNameUniqueness(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.parse.ParseUtils
 
validateFile(Set<String>, String) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
validateInput(FileSystem, HiveConf, ArrayList<FileStatus>) - Method in interface org.apache.hadoop.hive.ql.io.InputFormatChecker
This method is used to validate the input files.
validateInput(FileSystem, HiveConf, ArrayList<FileStatus>) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
 
validateInput(FileSystem, HiveConf, ArrayList<FileStatus>) - Method in class org.apache.hadoop.hive.ql.io.orc.VectorizedOrcInputFormat
 
validateInput(FileSystem, HiveConf, ArrayList<FileStatus>) - Method in class org.apache.hadoop.hive.ql.io.RCFileInputFormat
 
validateInput(FileSystem, HiveConf, ArrayList<FileStatus>) - Method in class org.apache.hadoop.hive.ql.io.SequenceFileInputFormatChecker
 
validateInput(JobConf) - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat
For backward compatibility with hadoop 0.17.
validateInput(FileSystem, HiveConf, ArrayList<FileStatus>) - Method in class org.apache.hadoop.hive.ql.io.VectorizedRCFileInputFormat
 
validateNoLeadLagInValueBoundarySpec(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
validatePartColumnNames(Map<String, String>, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
validatePartitionNameCharacters(List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
validatePartSpec(Table, Map<String, String>, ASTNode, HiveConf, boolean) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
validatePrivileges(List<HivePrivilege>) - Static method in class org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLAuthorizationUtils
Check if the privileges are acceptable for SQL Standard authorization implementation
validateSkewedColNames(List<String>, List<String>) - Static method in class org.apache.hadoop.hive.ql.plan.ValidationUtility
Skewed column name should be a valid column defined.
validateSkewedColNameValueNumberMatch(List<String>, List<List<String>>) - Static method in class org.apache.hadoop.hive.ql.plan.ValidationUtility
Skewed column name and value should match.
validateSkewedColumnNameUniqueness(List<String>) - Static method in class org.apache.hadoop.hive.ql.plan.ValidationUtility
Find out duplicate name.
validateSkewedInformation(List<String>, List<String>, List<List<String>>) - Static method in class org.apache.hadoop.hive.ql.plan.ValidationUtility
Validate skewed table information.
validateTargetDir(Path, Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.tez.DagUtils
 
ValidationUtility - Class in org.apache.hadoop.hive.ql.plan
Common utilities for validation.
validStats(Operator<? extends OperatorDesc>, ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.stats.CBOTableStatsValidator
 
ValueBoundaryDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
ValueBoundaryDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.ValueBoundaryDef
 
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.ErrorMsg
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.FilterOperator.Counter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.FunctionUtils.FunctionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.FunctionUtils.UDFClassType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.JoinOperator.SkewkeyTableCounter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.MapOperator.Counter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.Operator.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.ScriptOperator.Counter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.Task.FeedType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.Utilities.ReduceField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.Utilities.StreamStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.ArgumentType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.InputExpressionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.history.HiveHistory.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.history.HiveHistory.RecordTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.hooks.Entity.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.hooks.HookContext.HookType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.hooks.LineageInfo.DependencyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.hooks.WriteEntity.WriteType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.index.HiveIndex.IndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.io.IOContext.Comparison
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.io.orc.CompressionKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.OrcTableProperties
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.Version
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.io.parquet.convert.ETypeConverter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf.Operator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.io.sarg.SearchArgument.TruthValue
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.lockmgr.HiveLockMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.GroupByOptimizerSortMatch
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveJoinRel.JoinAlgorithm
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveJoinRel.MapJoinStreamingRelation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.WalkState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.optimizer.SamplePruner.LimitPruneRetStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec.SpecType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.parse.JoinType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFQueryInputType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.parse.QBExpr.Opcode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.parse.QBSubQuery.SubQueryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.parse.WindowingSpec.Direction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc.ALTER_DB_TYPES
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.AlterIndexDesc.AlterIndexTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.AlterTableDesc.AlterTableTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.AlterTableDesc.ProtectModeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.ArchiveWork.ArchiveActionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.FileSinkDesc.DPSortState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.GroupByDesc.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.HiveOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.PlanUtils.ExpressionTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.RoleDDLDesc.RoleOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.Statistics.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.TezEdgeProperty.EdgeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.processors.HiveCommand
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer.VERSION
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.HiveOperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrincipal.HivePrincipalType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject.HivePrivilegeObjectType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLPrivilegeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLPrivTypeGrant
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.session.SessionState.AuthorizationMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.session.SessionState.ResourceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare.CompareType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.hadoop.hive.ql.ErrorMsg
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.hadoop.hive.ql.exec.ArchiveUtils.PartSpecInfo
 
values() - Static method in enum org.apache.hadoop.hive.ql.exec.FilterOperator.Counter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.FunctionUtils.FunctionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.FunctionUtils.UDFClassType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.JoinOperator.SkewkeyTableCounter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.MapOperator.Counter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.Operator.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.ScriptOperator.Counter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.Task.FeedType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.Utilities.ReduceField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.Utilities.StreamStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.ArgumentType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.InputExpressionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.history.HiveHistory.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.history.HiveHistory.RecordTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.hooks.Entity.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.hooks.HookContext.HookType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.hooks.LineageInfo.DependencyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.hooks.WriteEntity.WriteType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.index.HiveIndex.IndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.io.IOContext.Comparison
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.io.orc.CompressionKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.OrcTableProperties
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.io.orc.OrcFile.Version
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.io.parquet.convert.ETypeConverter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf.Operator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.io.sarg.SearchArgument.TruthValue
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.lockmgr.HiveLockMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.GroupByOptimizerSortMatch
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveJoinRel.JoinAlgorithm
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveJoinRel.MapJoinStreamingRelation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.WalkState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.optimizer.SamplePruner.LimitPruneRetStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec.SpecType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.parse.JoinType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.PTFQueryInputType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.parse.QBExpr.Opcode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.parse.QBSubQuery.SubQueryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.parse.WindowingSpec.Direction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc.ALTER_DB_TYPES
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.AlterIndexDesc.AlterIndexTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.AlterTableDesc.AlterTableTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.AlterTableDesc.ProtectModeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.ArchiveWork.ArchiveActionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.FileSinkDesc.DPSortState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.GroupByDesc.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.HiveOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.PlanUtils.ExpressionTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.RoleDDLDesc.RoleOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.Statistics.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.TezEdgeProperty.EdgeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.processors.HiveCommand
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizer.VERSION
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.HiveOperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrincipal.HivePrincipalType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject.HivePrivilegeObjectType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLPrivilegeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLPrivTypeGrant
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.session.SessionState.AuthorizationMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.session.SessionState.ResourceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare.CompareType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.util.JavaDataModel
Returns an array containing the constants of this enum type, in the order they are declared.
valueWriters - Variable in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
VariableSubstitution - Class in org.apache.hadoop.hive.ql.parse
 
VariableSubstitution() - Constructor for class org.apache.hadoop.hive.ql.parse.VariableSubstitution
 
vector - Variable in class org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector
 
vector - Variable in class org.apache.hadoop.hive.ql.exec.vector.DecimalColumnVector
A vector if Decimal128 objects.
vector - Variable in class org.apache.hadoop.hive.ql.exec.vector.DoubleColumnVector
 
vector - Variable in class org.apache.hadoop.hive.ql.exec.vector.LongColumnVector
 
VectorAggregateExpression - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates
Base class for aggregation expressions.
VectorAggregateExpression() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorAggregateExpression
 
VectorAggregateExpression.AggregationBuffer - Interface in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates
Buffer interface to store aggregates.
VectorAggregationBufferBatch - Class in org.apache.hadoop.hive.ql.exec.vector
This maps a batch to the aggregation buffers sets to use for each row (key)
VectorAggregationBufferBatch() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferBatch
 
VectorAggregationBufferRow - Class in org.apache.hadoop.hive.ql.exec.vector
Represents a set of aggregation buffers to be used for a specific key for UDAF GROUP BY.
VectorAggregationBufferRow(VectorAggregateExpression.AggregationBuffer[]) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorAggregationBufferRow
 
VectorCoalesce - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
This expression returns the value of the first non-null expression in the given set of inputs expressions.
VectorCoalesce(int[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorCoalesce
 
VectorCoalesce() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorCoalesce
 
VectorColumnAssign - Interface in org.apache.hadoop.hive.ql.exec.vector
 
VectorColumnAssignFactory - Class in org.apache.hadoop.hive.ql.exec.vector
This class is used as a static factory for VectorColumnAssign.
VectorColumnAssignFactory() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorColumnAssignFactory
 
VectorExpression - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Base class for expressions.
VectorExpression() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpression
 
VectorExpression.Type - Enum in org.apache.hadoop.hive.ql.exec.vector.expressions
 
VectorExpressionDescriptor - Class in org.apache.hadoop.hive.ql.exec.vector
Describes a vector expression and encapsulates the VectorExpressionDescriptor.Mode, number of arguments, argument types VectorExpressionDescriptor.ArgumentType and expression types VectorExpressionDescriptor.InputExpressionType.
VectorExpressionDescriptor() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor
 
VectorExpressionDescriptor.ArgumentType - Enum in org.apache.hadoop.hive.ql.exec.vector
 
VectorExpressionDescriptor.Builder - Class in org.apache.hadoop.hive.ql.exec.vector
Builder builds a VectorExpressionDescriptor.Descriptor object.
VectorExpressionDescriptor.Builder() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorExpressionDescriptor.Builder
 
VectorExpressionDescriptor.Descriptor - Class in org.apache.hadoop.hive.ql.exec.vector
Descriptor is immutable and is constructed by the VectorExpressionDescriptor.Builder only.
VectorExpressionDescriptor.InputExpressionType - Enum in org.apache.hadoop.hive.ql.exec.vector
 
VectorExpressionDescriptor.Mode - Enum in org.apache.hadoop.hive.ql.exec.vector
 
VectorExpressionWriter - Interface in org.apache.hadoop.hive.ql.exec.vector.expressions
Interface used to create Writable objects from vector expression primitives.
VectorExpressionWriterFactory - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
VectorExpressionWritableFactory helper class for generating VectorExpressionWritable objects.
VectorExpressionWriterFactory() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriterFactory
 
VectorExpressionWriterFactory.ListOIDClosure - Interface in org.apache.hadoop.hive.ql.exec.vector.expressions
 
VectorExpressionWriterFactory.SingleOIDClosure - Interface in org.apache.hadoop.hive.ql.exec.vector.expressions
A poor man Java closure.
VectorFileSinkOperator - Class in org.apache.hadoop.hive.ql.exec.vector
File Sink operator implementation.
VectorFileSinkOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorFileSinkOperator
 
VectorFileSinkOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorFileSinkOperator
 
VectorFilterOperator - Class in org.apache.hadoop.hive.ql.exec.vector
Filter operator implementation.
VectorFilterOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorFilterOperator
 
VectorFilterOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorFilterOperator
 
VectorGroupByOperator - Class in org.apache.hadoop.hive.ql.exec.vector
Vectorized GROUP BY operator implementation.
VectorGroupByOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
VectorGroupByOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator
 
VectorHashKeyWrapper - Class in org.apache.hadoop.hive.ql.exec.vector
A hash map key wrapper for vectorized processing.
VectorHashKeyWrapper(int, int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper
 
VectorHashKeyWrapperBatch - Class in org.apache.hadoop.hive.ql.exec.vector
Class for handling vectorized hash map key wrappers.
VectorHashKeyWrapperBatch() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapperBatch
 
VectorizationContext - Class in org.apache.hadoop.hive.ql.exec.vector
Context class for vectorization execution.
VectorizationContext(Map<String, Integer>, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
 
VectorizationContext(VectorizationContext) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorizationContext
This constructor inherits the OutputColumnManger and from the 'parent' constructor, therefore this should be used only by operators that don't create a new vectorized row batch.
VectorizationContextRegion - Interface in org.apache.hadoop.hive.ql.exec.vector
VectorizationContextRegion optional interface implemented by vectorized operators that are changing the vectorizaiton context (region boundary operators)
VectorizedBatchUtil - Class in org.apache.hadoop.hive.ql.exec.vector
 
VectorizedBatchUtil() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil
 
VectorizedColumnarSerDe - Class in org.apache.hadoop.hive.ql.exec.vector
VectorizedColumnarSerDe is used by Vectorized query execution engine for columnar based storage supported by RCFile.
VectorizedColumnarSerDe() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorizedColumnarSerDe
 
VectorizedExpressions - Annotation Type in org.apache.hadoop.hive.ql.exec.vector
 
VectorizedInputFormatInterface - Interface in org.apache.hadoop.hive.ql.exec.vector
Marker interface to indicate a given input format supports vectorization input.
VectorizedOrcInputFormat - Class in org.apache.hadoop.hive.ql.io.orc
A MapReduce/Hive input format for ORC files.
VectorizedOrcInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.orc.VectorizedOrcInputFormat
 
VectorizedOrcSerde - Class in org.apache.hadoop.hive.ql.io.orc
A serde class for ORC.
VectorizedOrcSerde(ObjectInspector) - Constructor for class org.apache.hadoop.hive.ql.io.orc.VectorizedOrcSerde
 
VectorizedRCFileInputFormat - Class in org.apache.hadoop.hive.ql.io
A MapReduce/Hive Vectorized input format for RC files.
VectorizedRCFileInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.VectorizedRCFileInputFormat
 
VectorizedRCFileRecordReader - Class in org.apache.hadoop.hive.ql.io
RCFileRecordReader.
VectorizedRCFileRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.hive.ql.io.VectorizedRCFileRecordReader
 
VectorizedRowBatch - Class in org.apache.hadoop.hive.ql.exec.vector
A VectorizedRowBatch is a set of rows, organized with each column as a vector.
VectorizedRowBatch(int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
Return a batch with the specified number of columns.
VectorizedRowBatch(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
Return a batch with the specified number of columns and rows.
VectorizedRowBatchCtx - Class in org.apache.hadoop.hive.ql.exec.vector
Context for Vectorized row batch.
VectorizedRowBatchCtx(StructObjectInspector, StructObjectInspector, Deserializer, Map<String, Object>, Map<String, PrimitiveObjectInspector.PrimitiveCategory>) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatchCtx
Constructor for VectorizedRowBatchCtx
VectorizedRowBatchCtx() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatchCtx
Constructor for VectorizedRowBatchCtx
VectorizedSerde - Interface in org.apache.hadoop.hive.ql.exec.vector
Serdes that support vectorized VectorizedRowBatch must implement this interface.
Vectorizer - Class in org.apache.hadoop.hive.ql.optimizer.physical
 
Vectorizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.Vectorizer
 
VectorLimitOperator - Class in org.apache.hadoop.hive.ql.exec.vector
Limit operator implementation Limits the number of rows to be passed on.
VectorLimitOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorLimitOperator
 
VectorLimitOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorLimitOperator
 
VectorMapJoinOperator - Class in org.apache.hadoop.hive.ql.exec.vector
The vectorized version of the MapJoinOperator.
VectorMapJoinOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator
 
VectorMapJoinOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator
 
VectorMapOperator - Class in org.apache.hadoop.hive.ql.exec.vector
 
VectorMapOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorMapOperator
 
vectorOpvec - Static variable in class org.apache.hadoop.hive.ql.exec.OperatorFactory
 
VectorReduceSinkOperator - Class in org.apache.hadoop.hive.ql.exec.vector
 
VectorReduceSinkOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator
 
VectorReduceSinkOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator
 
VectorSelectOperator - Class in org.apache.hadoop.hive.ql.exec.vector
Select operator implementation.
VectorSelectOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator
 
VectorSelectOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator
 
VectorSMBMapJoinOperator - Class in org.apache.hadoop.hive.ql.exec.vector
VectorSMBJoinOperator.
VectorSMBMapJoinOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorSMBMapJoinOperator
 
VectorSMBMapJoinOperator(VectorizationContext, OperatorDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorSMBMapJoinOperator
 
VectorUDAFAvgDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates
Generated from template VectorUDAFAvg.txt.
VectorUDAFAvgDecimal(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFAvgDecimal
 
VectorUDAFAvgDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFAvgDecimal
 
VectorUDAFCount - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates
VectorUDAFCountLong.
VectorUDAFCount(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCount
 
VectorUDAFCount() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCount
 
VectorUDAFCountStar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates
VectorUDAFCountStar.
VectorUDAFCountStar(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCountStar
 
VectorUDAFCountStar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFCountStar
 
VectorUDAFSumDecimal - Class in org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates
VectorUDAFSumDecimal.
VectorUDAFSumDecimal(VectorExpression) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFSumDecimal
 
VectorUDAFSumDecimal() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFSumDecimal
 
VectorUDFAdaptor - Class in org.apache.hadoop.hive.ql.exec.vector.udf
A VectorUDFAdaptor is a vectorized expression for invoking a custom UDF on zero or more input vectors or constants which are the function arguments.
VectorUDFAdaptor() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
VectorUDFAdaptor(ExprNodeGenericFuncDesc, int, String, VectorUDFArgDesc[]) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFAdaptor
 
VectorUDFArgDesc - Class in org.apache.hadoop.hive.ql.exec.vector.udf
Descriptor for function argument.
VectorUDFArgDesc() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.udf.VectorUDFArgDesc
 
VectorUDFDateAddColCol - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
VectorUDFDateAddColCol(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol
 
VectorUDFDateAddColCol() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol
 
VectorUDFDateAddColScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
VectorUDFDateAddColScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
VectorUDFDateAddColScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar
 
VectorUDFDateAddScalarCol - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
VectorUDFDateAddScalarCol() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
VectorUDFDateAddScalarCol(Object, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddScalarCol
 
VectorUDFDateDiffColCol - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
VectorUDFDateDiffColCol(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColCol
 
VectorUDFDateDiffColCol() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColCol
 
VectorUDFDateDiffColScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
VectorUDFDateDiffColScalar(int, Object, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
VectorUDFDateDiffColScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColScalar
 
VectorUDFDateDiffScalarCol - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
VectorUDFDateDiffScalarCol(Object, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
VectorUDFDateDiffScalarCol() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffScalarCol
 
VectorUDFDateLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
VectorUDFDateLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateLong
 
VectorUDFDateLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateLong
 
VectorUDFDateString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
VectorUDFDateString(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateString
 
VectorUDFDateString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateString
 
VectorUDFDateSubColCol - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Returns the date that is num_days before start_date.
VectorUDFDateSubColCol(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateSubColCol
 
VectorUDFDateSubColCol() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateSubColCol
 
VectorUDFDateSubColScalar - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Returns the date that is num_days before start_date.
VectorUDFDateSubColScalar(int, long, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateSubColScalar
 
VectorUDFDateSubColScalar() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateSubColScalar
 
VectorUDFDateSubScalarCol - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
 
VectorUDFDateSubScalarCol(Object, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateSubScalarCol
 
VectorUDFDateSubScalarCol() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateSubScalarCol
 
VectorUDFDayOfMonthLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Expression to get day of month.
VectorUDFDayOfMonthLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDayOfMonthLong
 
VectorUDFDayOfMonthLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDayOfMonthLong
 
VectorUDFDayOfMonthString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Expression to get day of month.
VectorUDFDayOfMonthString(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDayOfMonthString
 
VectorUDFDayOfMonthString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDayOfMonthString
 
VectorUDFHourLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Returns hour of day.
VectorUDFHourLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFHourLong
 
VectorUDFHourLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFHourLong
 
VectorUDFHourString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Returns hour of day.
VectorUDFHourString(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFHourString
 
VectorUDFHourString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFHourString
 
VectorUDFMinuteLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Returns minute value.
VectorUDFMinuteLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFMinuteLong
 
VectorUDFMinuteLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFMinuteLong
 
VectorUDFMinuteString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Returns minute value.
VectorUDFMinuteString(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFMinuteString
 
VectorUDFMinuteString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFMinuteString
 
VectorUDFMonthLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Returns month value.
VectorUDFMonthLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFMonthLong
 
VectorUDFMonthLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFMonthLong
 
VectorUDFMonthString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Returns month value.
VectorUDFMonthString(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFMonthString
 
VectorUDFMonthString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFMonthString
 
VectorUDFSecondLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Expression to get seconds.
VectorUDFSecondLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFSecondLong
 
VectorUDFSecondLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFSecondLong
 
VectorUDFSecondString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Expression to get seconds.
VectorUDFSecondString(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFSecondString
 
VectorUDFSecondString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFSecondString
 
VectorUDFTimestampFieldLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Abstract class to return various fields from a Timestamp or Date.
VectorUDFTimestampFieldLong(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
VectorUDFTimestampFieldLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldLong
 
VectorUDFTimestampFieldString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Abstract class to return various fields from a String.
VectorUDFTimestampFieldString(int, int, int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldString
 
VectorUDFTimestampFieldString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldString
 
VectorUDFUnixTimeStampLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Return Unix Timestamp.
VectorUDFUnixTimeStampLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFUnixTimeStampLong
 
VectorUDFUnixTimeStampLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFUnixTimeStampLong
 
VectorUDFUnixTimeStampString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Return Unix Timestamp.
VectorUDFUnixTimeStampString(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFUnixTimeStampString
 
VectorUDFUnixTimeStampString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFUnixTimeStampString
 
VectorUDFWeekOfYearLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Expression to get week of year.
VectorUDFWeekOfYearLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFWeekOfYearLong
 
VectorUDFWeekOfYearLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFWeekOfYearLong
 
VectorUDFWeekOfYearString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Expression to get week of year.
VectorUDFWeekOfYearString(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFWeekOfYearString
 
VectorUDFWeekOfYearString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFWeekOfYearString
 
VectorUDFYearLong - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Expression to get year as a long.
VectorUDFYearLong(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFYearLong
 
VectorUDFYearLong() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFYearLong
 
VectorUDFYearString - Class in org.apache.hadoop.hive.ql.exec.vector.expressions
Expression to get year as a long.
VectorUDFYearString(int, int) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFYearString
 
VectorUDFYearString() - Constructor for class org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFYearString
 
VectorUtilBatchObjectPool<T> - Class in org.apache.hadoop.hive.ql.exec.vector
 
VectorUtilBatchObjectPool(int, VectorUtilBatchObjectPool.IAllocator<T>) - Constructor for class org.apache.hadoop.hive.ql.exec.vector.VectorUtilBatchObjectPool
 
VectorUtilBatchObjectPool.IAllocator<T> - Interface in org.apache.hadoop.hive.ql.exec.vector
 
version(OrcFile.Version) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFile.WriterOptions
Sets the version of the file that will be written.
VIRTUAL_COLUMNS - Static variable in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
VirtualColumn - Class in org.apache.hadoop.hive.ql.metadata
 
VirtualColumn() - Constructor for class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
VirtualColumn(String, PrimitiveTypeInfo) - Constructor for class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
visit(Object, Object, int, Map) - Method in class org.apache.hadoop.hive.ql.parse.PTFTranslator.ValidateNoLeadLag
 
visit(Object, TreeWizard.ContextVisitor) - Static method in class org.apache.hadoop.hive.ql.parse.PTFTranslator
 
visit(ExprNodeGenericFuncDesc) - Method in class org.apache.hadoop.hive.ql.parse.WindowingExprNodeEvaluatorFactory.FindLeadLagFuncExprs
 
visitCall(RexCall) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.stats.FilterSelectivityEstimator
 
visitChild(int, RelNode) - Method in class org.apache.hadoop.hive.ql.optimizer.optiq.reloperators.HiveRel.Implementor
 
visitedReduceSinks - Variable in class org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext
 

W

w - Variable in class org.apache.hadoop.hive.ql.plan.TezWork.Dependency
 
walk(Node) - Method in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
walk the current operator and its descendants.
walk(Node) - Method in class org.apache.hadoop.hive.ql.lib.ForwardWalker
walk the current operator and its descendants.
walk(Node) - Method in class org.apache.hadoop.hive.ql.lib.PreOrderWalker
Walk the current operator and its descendants.
walk(Node) - Method in class org.apache.hadoop.hive.ql.lib.TaskGraphWalker
walk the current operator and its descendants.
walk(Node) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPruner.ColumnPrunerWalker
Walk the given operator.
walk(Node) - Method in class org.apache.hadoop.hive.ql.parse.GenMapRedWalker
Walk the given operator.
walk(Node) - Method in class org.apache.hadoop.hive.ql.parse.GenTezWorkWalker
Walk the given operator.
walk(Node) - Method in class org.apache.hadoop.hive.ql.parse.TezWalker
Walk the given operator.
walkExprTree(String, ArrayList<Partition>, List<VirtualColumn>, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory
Remove partition conditions when necessary from the the expression tree.
walkExprTree(ExprNodeDesc, NodeProcessorCtx, NodeProcessor, NodeProcessor, NodeProcessor, NodeProcessor) - Static method in class org.apache.hadoop.hive.ql.optimizer.PrunerUtils
Walk expression tree for pruner generation.
walkOperatorTree(ParseContext, NodeProcessorCtx, NodeProcessor, NodeProcessor) - Static method in class org.apache.hadoop.hive.ql.optimizer.PrunerUtils
Walk operator tree for pruner generation.
WindowExpressionDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
WindowExpressionDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.WindowExpressionDef
 
WindowExpressionDef(PTFExpressionDef) - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.WindowExpressionDef
 
WindowFrameDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
WindowFrameDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.WindowFrameDef
 
WindowFunctionDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
WindowFunctionDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.WindowFunctionDef
 
WindowFunctionDescription - Annotation Type in org.apache.hadoop.hive.ql.exec
 
WindowFunctionInfo - Class in org.apache.hadoop.hive.ql.exec
 
WINDOWING_TABLE_FUNCTION - Static variable in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
WindowingComponentizer - Class in org.apache.hadoop.hive.ql.parse
 
WindowingComponentizer(WindowingSpec) - Constructor for class org.apache.hadoop.hive.ql.parse.WindowingComponentizer
 
WindowingExprNodeEvaluatorFactory - Class in org.apache.hadoop.hive.ql.parse
 
WindowingExprNodeEvaluatorFactory() - Constructor for class org.apache.hadoop.hive.ql.parse.WindowingExprNodeEvaluatorFactory
 
WindowingExprNodeEvaluatorFactory.FindLeadLagFuncExprs - Class in org.apache.hadoop.hive.ql.parse
 
WindowingSpec - Class in org.apache.hadoop.hive.ql.parse
 
WindowingSpec() - Constructor for class org.apache.hadoop.hive.ql.parse.WindowingSpec
 
WindowingSpec.BoundarySpec - Class in org.apache.hadoop.hive.ql.parse
 
WindowingSpec.BoundarySpec() - Constructor for class org.apache.hadoop.hive.ql.parse.WindowingSpec.BoundarySpec
 
WindowingSpec.CurrentRowSpec - Class in org.apache.hadoop.hive.ql.parse
 
WindowingSpec.CurrentRowSpec() - Constructor for class org.apache.hadoop.hive.ql.parse.WindowingSpec.CurrentRowSpec
 
WindowingSpec.Direction - Enum in org.apache.hadoop.hive.ql.parse
 
WindowingSpec.RangeBoundarySpec - Class in org.apache.hadoop.hive.ql.parse
 
WindowingSpec.RangeBoundarySpec() - Constructor for class org.apache.hadoop.hive.ql.parse.WindowingSpec.RangeBoundarySpec
 
WindowingSpec.RangeBoundarySpec(WindowingSpec.Direction, int) - Constructor for class org.apache.hadoop.hive.ql.parse.WindowingSpec.RangeBoundarySpec
 
WindowingSpec.ValueBoundarySpec - Class in org.apache.hadoop.hive.ql.parse
 
WindowingSpec.ValueBoundarySpec() - Constructor for class org.apache.hadoop.hive.ql.parse.WindowingSpec.ValueBoundarySpec
 
WindowingSpec.ValueBoundarySpec(WindowingSpec.Direction, int) - Constructor for class org.apache.hadoop.hive.ql.parse.WindowingSpec.ValueBoundarySpec
 
WindowingSpec.WindowExpressionSpec - Class in org.apache.hadoop.hive.ql.parse
 
WindowingSpec.WindowExpressionSpec() - Constructor for class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowExpressionSpec
 
WindowingSpec.WindowFrameSpec - Class in org.apache.hadoop.hive.ql.parse
 
WindowingSpec.WindowFrameSpec() - Constructor for class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFrameSpec
 
WindowingSpec.WindowFrameSpec(WindowingSpec.BoundarySpec, WindowingSpec.BoundarySpec) - Constructor for class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFrameSpec
 
WindowingSpec.WindowFrameSpec(WindowingSpec.BoundarySpec) - Constructor for class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFrameSpec
 
WindowingSpec.WindowFunctionSpec - Class in org.apache.hadoop.hive.ql.parse
 
WindowingSpec.WindowFunctionSpec() - Constructor for class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowFunctionSpec
 
WindowingSpec.WindowSpec - Class in org.apache.hadoop.hive.ql.parse
 
WindowingSpec.WindowSpec() - Constructor for class org.apache.hadoop.hive.ql.parse.WindowingSpec.WindowSpec
 
WindowingTableFunction - Class in org.apache.hadoop.hive.ql.udf.ptf
 
WindowingTableFunction() - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction
 
WindowingTableFunction.DoubleValueBoundaryScanner - Class in org.apache.hadoop.hive.ql.udf.ptf
 
WindowingTableFunction.DoubleValueBoundaryScanner(BoundaryDef, PTFInvocationSpec.Order, PTFExpressionDef) - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.DoubleValueBoundaryScanner
 
WindowingTableFunction.LongValueBoundaryScanner - Class in org.apache.hadoop.hive.ql.udf.ptf
 
WindowingTableFunction.LongValueBoundaryScanner(BoundaryDef, PTFInvocationSpec.Order, PTFExpressionDef) - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.LongValueBoundaryScanner
 
WindowingTableFunction.SameList<E> - Class in org.apache.hadoop.hive.ql.udf.ptf
 
WindowingTableFunction.SameList(int, E) - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.SameList
 
WindowingTableFunction.StringValueBoundaryScanner - Class in org.apache.hadoop.hive.ql.udf.ptf
 
WindowingTableFunction.StringValueBoundaryScanner(BoundaryDef, PTFInvocationSpec.Order, PTFExpressionDef) - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.StringValueBoundaryScanner
 
WindowingTableFunction.WindowingTableFunctionResolver - Class in org.apache.hadoop.hive.ql.udf.ptf
 
WindowingTableFunction.WindowingTableFunctionResolver() - Constructor for class org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.WindowingTableFunctionResolver
 
WindowTableFunctionDef - Class in org.apache.hadoop.hive.ql.plan.ptf
 
WindowTableFunctionDef() - Constructor for class org.apache.hadoop.hive.ql.plan.ptf.WindowTableFunctionDef
 
workClass - Variable in class org.apache.hadoop.hive.ql.exec.TaskFactory.TaskTuple
 
Worker - Class in org.apache.hadoop.hive.ql.txn.compactor
A class to do compactions.
Worker() - Constructor for class org.apache.hadoop.hive.ql.txn.compactor.Worker
 
workWithUnionOperators - Variable in class org.apache.hadoop.hive.ql.parse.GenTezProcContext
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
 
write(Writable) - Method in interface org.apache.hadoop.hive.ql.exec.FileSinkOperator.RecordWriter
 
write(MapJoinObjectSerDeContext, ObjectOutputStream) - Method in class org.apache.hadoop.hive.ql.exec.persistence.LazyFlatRowContainer
 
write(MapJoinObjectSerDeContext, ObjectOutputStream) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinEagerRowContainer
 
write(MapJoinObjectSerDeContext, ObjectOutputStream) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKey
 
write(MapJoinObjectSerDeContext, ObjectOutputStream) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyBytes
 
write(MapJoinObjectSerDeContext, ObjectOutputStream) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinKeyObject
 
write(MapJoinObjectSerDeContext, ObjectOutputStream) - Method in interface org.apache.hadoop.hive.ql.exec.persistence.MapJoinRowContainer
 
write(Writable) - Method in interface org.apache.hadoop.hive.ql.exec.RecordWriter
 
write(Writable) - Method in class org.apache.hadoop.hive.ql.exec.TextRecordWriter
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch
 
write(int) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
write(byte[]) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
write(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
write(Writable) - Method in class org.apache.hadoop.hive.ql.io.avro.AvroGenericRecordWriter
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Writable interface.
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
write(Writable) - Method in class org.apache.hadoop.hive.ql.io.HivePassThroughRecordWriter
 
write(DataInput, int) - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataOutputBuffer
Writes bytes from a DataInput directly into the buffer.
write(int) - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataOutputBuffer
 
write(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataOutputBuffer
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.NullRowsInputFormat.DummyInputSplit
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcNewSplit
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcSplit
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcStruct
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BinaryWritable
 
write(ArrayWritable) - Method in class org.apache.hadoop.hive.ql.io.parquet.write.DataWritableWriter
 
write(ArrayWritable) - Method in class org.apache.hadoop.hive.ql.io.parquet.write.DataWritableWriteSupport
 
write(Void, ArrayWritable) - Method in class org.apache.hadoop.hive.ql.io.parquet.write.ParquetRecordWriterWrapper
 
write(Writable) - Method in class org.apache.hadoop.hive.ql.io.parquet.write.ParquetRecordWriterWrapper
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.RCFile.KeyBuffer
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileKeyBufferWrapper
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.rcfile.merge.RCFileValueBufferWrapper
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.RCFile.ValueBuffer
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.RecordIdentifier
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat.SymlinkTextInputSplit
 
writeBoolean(boolean) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeByte(int) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeBytes(String) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeChar(int) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeChars(String) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeDouble(double) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
WriteEntity - Class in org.apache.hadoop.hive.ql.hooks
This class encapsulates an object that is being written to by the query.
WriteEntity() - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
Only used by serialization.
WriteEntity(Database, WriteEntity.WriteType) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
WriteEntity(Table, WriteEntity.WriteType) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
Constructor for a table.
WriteEntity(Table, WriteEntity.WriteType, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
WriteEntity(Partition, WriteEntity.WriteType) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
Constructor for a partition.
WriteEntity(DummyPartition, WriteEntity.WriteType, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
WriteEntity(Path, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
Constructor for a file.
WriteEntity(Path, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
Constructor for a file.
WriteEntity.WriteType - Enum in org.apache.hadoop.hive.ql.hooks
 
writeFloat(float) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeInt(int) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeIntermediateFooter() - Method in interface org.apache.hadoop.hive.ql.io.orc.Writer
Write an intermediate footer on the file such that if the file is truncated to the returned offset, it would be a valid ORC file.
writeLong(long) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeLongToUTF8(byte[], long) - Static method in class org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr
 
writeObject(Object) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writePartitionKeys(Path, JobConf) - Method in class org.apache.hadoop.hive.ql.exec.PartitionKeySampler
 
Writer - Interface in org.apache.hadoop.hive.ql.io.orc
The interface for writing ORC files.
writerOptions(Configuration) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcFile
Create a default set of write options that can be modified.
writeShort(int) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeToByteStream(ByteStream.Output) - Method in class org.apache.hadoop.hive.ql.io.parquet.writable.BigDecimalWritable
 
writeUTF(String) - Method in class org.apache.hadoop.hive.ql.index.bitmap.BitmapObjectOutput
 
writeValue(ColumnVector, int) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriter
 
writeValue(long) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriter
 
writeValue(double) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriter
 
writeValue(byte[], int, int) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriter
 
writeValue(Decimal128) - Method in interface org.apache.hadoop.hive.ql.exec.vector.expressions.VectorExpressionWriter
 
writingBase(boolean) - Method in class org.apache.hadoop.hive.ql.io.AcidOutputFormat.Options
Is this writing a base directory? Should only be used by the compactor, or when implementing insert overwrite.

Z

ZooKeeperHiveLock - Class in org.apache.hadoop.hive.ql.lockmgr.zookeeper
 
ZooKeeperHiveLock(String, HiveLockObject, HiveLockMode) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock
 
ZooKeeperHiveLockManager - Class in org.apache.hadoop.hive.ql.lockmgr.zookeeper
 
ZooKeeperHiveLockManager() - Constructor for class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
ZooKeeperHiveLockManager.DummyWatcher - Class in org.apache.hadoop.hive.ql.lockmgr.zookeeper
 
ZooKeeperHiveLockManager.DummyWatcher() - Constructor for class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager.DummyWatcher
 

A B C D E F G H I J K L M N O P Q R S T U V W Z

Copyright © 2014 The Apache Software Foundation. All rights reserved.